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 2023/01/28 03:28:34 UTC

Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1220

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

Changes:

[Robert Bradshaw] Add some more links to the case studies page.

[Robert Bradshaw] Log BatchElement statistics.

[noreply] [24469] Implement CsvIO.Write and supporting classes (#24630)

[noreply] Implement mongodbio.Read with an SDF (#25160)


------------------------------------------
[...truncated 1016.95 KB...]
2023/01/28 03:24:51 Job still running ...
2023/01/28 03:25:21 Job still running ...
2023/01/28 03:25:51 Job still running ...
2023/01/28 03:26:21 Job still running ...
2023/01/28 03:26:51 Job still running ...
2023/01/28 03:27:21 Job still running ...
2023/01/28 03:27:51 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-27_19_18_50-17423368655332005921 failed
--- FAIL: TestXLang_Partition (583.98s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3326.728s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674873178306639216
--- FAIL: TestBigQueryIO_BasicWriteRead (4.15s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42425 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@LBnLpoBEKz" is_bounded:BOUNDED windowing_strategy_id:"w0@LBnLpoBEKz"}} windowing_strategies:{key:"w0@LBnLpoBEKz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@LBnLpoBEKz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@LBnLpoBEKz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@LBnLpoBEKz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674873178306639216\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"LBnLpoBEKz"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42425 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@LBnLpoBEKz" is_bounded:BOUNDED windowing_strategy_id:"w0@LBnLpoBEKz"}} windowing_strategies:{key:"w0@LBnLpoBEKz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@LBnLpoBEKz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@LBnLpoBEKz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@LBnLpoBEKz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674873178306639216\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"LBnLpoBEKz"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0002e16c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0002e16c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6a80?, 0xc0001399a0?}, {0x110f943, 0x39}, {0xc00015a0c0?, 0xa969c0?, 0x1?}, {0xc0005a4c00, 0xf}, 0xc000207d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6a20?, 0xc0001399a0?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc000207ea8, 0x2, 0x7f65b84ef5d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005a4c00, 0xf}, {0xc00004c5a0, 0x52}, {0xe96fa0, 0xc0005a5f10})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00035a680)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00035a680, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.187s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-023222
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-023222
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d97e68d36fffe3ec06c83ac695eef65aacfff084bd5209d9c6ae3a9f535fe2db
Deleted: sha256:1bbd2d0df821f88bd37c4f928217f897421af2dd05e0867c644348b657c46b07
Deleted: sha256:6bbac68dfcf8cb9210c37eb0de99ac2fcead55c2ddec1f6dc871b6951b545d89
Deleted: sha256:631e8934c208e1fe9ffb412de51c5e7a446b4f50f07b17f8961b823fc119b031
Deleted: sha256:ce3f3d6a8d65cb5e43ea0acbf3a136d505e48f0ea936fec00200bf69eb701492
Deleted: sha256:5ce00e07b79e256d84604bd4601d9a334b31e30118201b93ed48b1bf72b39efa
Deleted: sha256:df1443367f97b58ba8488ff3c1e85cdb85f9804ec99a7cd5668c4af60f024759
Deleted: sha256:205fd7f3d3ece3a1ccea48b9afff7999c0ce6df3ba606f687bb5cbcae9a14af5
Deleted: sha256:86db5c346fdf6d00d94b7aa639b6fdc314f05eabe2d128ad36a2300299d69930
Deleted: sha256:642caed76f4d04bc24782495e3d6a2e36108e7e8c45f5d76b6a29e4091589e4c
Deleted: sha256:583845efbc216a7cf4987f50043aa833e9aca86ebd8bb0e143be5dc47fa1c5c4
Deleted: sha256:d9cb42101f21d3785c7cede3aebf9821c10b17bd96fe00f241fe24031a4af302
Deleted: sha256:72749833d0b38e65f0f9099df84f449b54ceddb1b75b33e5b44181ce6ac9c96c
Deleted: sha256:2070647aa6f1e9fa1a33b05a4129b4b413b3405c76a8241a7405aa803098a054
Deleted: sha256:cc8d3f5961ec4521688c4c69cf2a8a396f7bc2c5e7cb135da27afe50f6112097
Deleted: sha256:c74416224c757345c1a1fc48e35115771018076ee010010d8b1dd3ecdc704bef
Deleted: sha256:f6b4f5c1d10f6004cb58c5fdbaaa34219a4690988a149ea2d7497e2810337cfd
Deleted: sha256:f1bd77f9e90eb36fb89ad0d5a8b7b740d03237e49a3db666380a4083f95592a2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-023222
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d97e68d36fffe3ec06c83ac695eef65aacfff084bd5209d9c6ae3a9f535fe2db
  Associated tags:
 - 20230128-023222
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-023222
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-023222].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d97e68d36fffe3ec06c83ac695eef65aacfff084bd5209d9c6ae3a9f535fe2db].
$ rm -rf /tmp/tmp.4N68F4w6fj
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f2039f4e2e82a13edd648b3130e693870395195420cf575f24014e64bd51332c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c
Deleted: sha256:6dcbb20015eb13a591e3fd21cd38af102b87877056265379b1af88802fb7ecb1
Deleted: sha256:eb2f032524e1c32eefc3800b257a92af5618496df48eeee10262430e2e90d8c2
Deleted: sha256:19e58a1f81904a22c88e16b7d6e9a54671f3c90f6749a2a44424199d00ae9864
Deleted: sha256:0de094e4999f67add7cdbb0bc27e44900f2ca4a36e794e7d12430a5a291bc295
Deleted: sha256:d41e4540b2c221cd61df02450d744fcabaf09a378364a66c488a39ce91e753fc
Deleted: sha256:295828f7049ab0952401dbefe3c15e8830d31ff832908a0c69bcb9c774a0c208
Deleted: sha256:5c3f4379b259ed36e05198062cb5544614e440324a097d7f05b7c93028243c5f
Deleted: sha256:ead193d1bcfb464cbb011c62f238a44fe16da37fea16b07d7a7587405eeab373
Deleted: sha256:9fc3e6e15399c5c0b15b9c058c634c988fe7ddfc3fb3cef3f223cbbdf7315487
Deleted: sha256:e374c11f743ebd8b0461b96dc065827e7afe50fcd4bc476b8f32d71660173c14
Deleted: sha256:14f78d3b54202d208ef61611afee9c9c255a0e2af42b815db6836f6403614911
Deleted: sha256:fd7712cb3176723e547ac5902ff0937dd0cf229be872796a8d703015eb36f532
Deleted: sha256:bf3df53b110e3fa2e3b349aff86d38d333ea3dff75547d1d9bf0cf92dbe7aa9b
Deleted: sha256:02bb1c17a1cdd1808c30d8dcd4ca3c571a522cbb4ba622e7d2615de0eb96e8d4
Deleted: sha256:14aaa2cc8186cd434ac6685dc0653a7e918e5362bc7a15d2298ec6bdcc5e8421
Deleted: sha256:49db15de5691ffed913b0bc37966ae3706ac0d6ed001bd84faaa4fac2f0c5500
Deleted: sha256:9ce90f9921a5b3524511fe6e8a6520a478dd99210463c60ddbe5edb56ad6e5ce
Deleted: sha256:03d2c35284b17a5f7c4fe3c8bd1c90ff3548865740457a02e731b7dd4eb6b379
Deleted: sha256:446ad101f6fea2e692719639a10739514807e684e63ace0d098d03c2fd1987c7
Deleted: sha256:552205b626462d15359a473f6382381218ec9f061aa2f71e2575d3c5cf987704
Deleted: sha256:5905a68ea7fd67f339fe825c273b4cbc568d008825cec5685ea74160cd943fb7
Deleted: sha256:48b5dc50bdeb83fc335fc87afab89b00258999c243d96115891dd1ec77c7236d
Deleted: sha256:cd054055bd4c406dbb306e4211607ae82a78cdbc571037ebbadf8fdd40181586
Deleted: sha256:cf14d3cea8eeb73e036909767e2007f9ad89e61fad09ea0cb2bc6f0ce7bf9768
Deleted: sha256:04bac20475a9e3ee1df1a3bd643cbe12e3c93d117b3da5f64831db3fcde585ec
Deleted: sha256:f879e57cec8ee6430a045f968f7177a95e592ac2817e7496bedb7adc5f954720
Deleted: sha256:a3b066059fc7b3b03422290fe0d42ae547cec6bfe0a86b30f6843b097ff6c40b
Deleted: sha256:16f7e46eee200dee0b0f824688854129942503977248e6584d004694f42ecee8
Deleted: sha256:75f9dbe47c8b42d02d7a3e03dc19e5722b95eaa69a796140c2120f7bc839a592
Deleted: sha256:e29c58a78216a699b335cf44afb0c34efb28d30b4f2b56f079430ed52e9aae79
Deleted: sha256:4fd15a0ff3e7cba9e2f9aaac1416c8f1b4a15ddaa288e83cfc7c13afbbe65005
Deleted: sha256:3a7505b240f4b189c628fe9dc28937717f0c8663f9061130bb6b0b964d34c67f
Deleted: sha256:ddc6070a8e5ad80256e2963f968f98393a2d72d5b2533d2ed510e553d41a5b62
Deleted: sha256:21db218cbe46377d428d6074c3ffbcdcf085eb0eb4d0750acd8843e976087e0f
Deleted: sha256:e61ced61960d93c8d41dd25317978644c952709e0af349a2e926071075a10e12
Deleted: sha256:e3ddac8c2151e9aedfd77e0698c8d42168c91b9dace333bee2dc01806a8f2c81
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:54086092f04c82098924200ae1059b5577d13ed83d3ad71340b30d12f812486c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 454567.
Stopping expansion service pid: 454568.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1472

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1472/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-083044",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401082027",
            "environmentId": "RxIGjWcuYCbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-083044"
      }
    ]
  },
  "name": "go-testxlang_partition-969",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/04/01 09:17:46 Submitted job: 2023-04-01_02_17_46-16621673837502783300
2023/04/01 09:17:46 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-04-01_02_17_46-16621673837502783300?project=apache-beam-testing
2023/04/01 09:17:46 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-04-01_02_17_46-16621673837502783300
2023/04/01 09:17:47 Job state: JOB_STATE_PENDING ...
2023/04/01 09:18:17 Job still running ...
2023/04/01 09:18:47 Job still running ...
2023/04/01 09:19:17 Job still running ...
2023/04/01 09:19:47 Job still running ...
2023/04/01 09:20:17 Job still running ...
2023/04/01 09:20:47 Job still running ...
2023/04/01 09:21:17 Job still running ...
2023/04/01 09:21:47 Job still running ...
2023/04/01 09:22:17 Job still running ...
2023/04/01 09:22:47 Job still running ...
2023/04/01 09:23:17 Job still running ...
2023/04/01 09:23:47 Job still running ...
2023/04/01 09:24:17 Job still running ...
2023/04/01 09:24:47 Job still running ...
2023/04/01 09:25:17 Job still running ...
2023/04/01 09:25:47 Job still running ...
2023/04/01 09:26:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-04-01_02_17_46-16621673837502783300 failed
--- FAIL: TestXLang_Partition (549.93s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3326.224s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680337884672067493
--- FAIL: TestBigQueryIO_BasicWriteRead (4.50s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37017 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FDsABFXZMr" is_bounded:BOUNDED windowing_strategy_id:"w0@FDsABFXZMr"}} windowing_strategies:{key:"w0@FDsABFXZMr" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FDsABFXZMr" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FDsABFXZMr" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FDsABFXZMr" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680337884672067493\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FDsABFXZMr"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37017 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FDsABFXZMr" is_bounded:BOUNDED windowing_strategy_id:"w0@FDsABFXZMr"}} windowing_strategies:{key:"w0@FDsABFXZMr" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FDsABFXZMr" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FDsABFXZMr" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FDsABFXZMr" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680337884672067493\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FDsABFXZMr"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 15 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc00011b6c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc00011b6c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001180e0?, 0xc0000bc280?}, {0x1137c73, 0x39}, {0xc0000f00c0?, 0xa9d780?, 0x1?}, {0xc0003eeb50, 0xf}, 0xc000535d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000118020?, 0xc0000bc280?}, {0xc0003fc300, 0x52}, {0x1?}, {0xc000535ea8, 0x2, 0xe79320?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003eeb50, 0xf}, {0xc0003fc300, 0x52}, {0xeba2e0, 0xc000110148})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000580b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000580b60, 0x1169b88)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.534s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:762faaeafcf3abf94598ffe8c5b57dc60651cdbbc0064bc8c7f9ff75953dd29a
  Associated tags:
 - 20230401-083044
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-083044
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-083044].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:762faaeafcf3abf94598ffe8c5b57dc60651cdbbc0064bc8c7f9ff75953dd29a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230401082027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cca1c19bf0e3ace3d49e633c004b00c5b171c66a91c987d8495fa4f7e1f40cac]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230401082027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cca1c19bf0e3ace3d49e633c004b00c5b171c66a91c987d8495fa4f7e1f40cac])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cca1c19bf0e3ace3d49e633c004b00c5b171c66a91c987d8495fa4f7e1f40cac
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cca1c19bf0e3ace3d49e633c004b00c5b171c66a91c987d8495fa4f7e1f40cac].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401082027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:74d2b734065dee565f82eef41c343c91030a132477f35218b86d758726ce18e8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401082027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:74d2b734065dee565f82eef41c343c91030a132477f35218b86d758726ce18e8])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:74d2b734065dee565f82eef41c343c91030a132477f35218b86d758726ce18e8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:74d2b734065dee565f82eef41c343c91030a132477f35218b86d758726ce18e8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 3s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1471

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1471/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401022030",
            "environmentId": "lVofTyKXSUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056"
      }
    ]
  },
  "name": "go-testxlang_partition-750",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/04/01 03:17:02 Submitted job: 2023-03-31_20_17_01-15536349017889844599
2023/04/01 03:17:02 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-31_20_17_01-15536349017889844599?project=apache-beam-testing
2023/04/01 03:17:02 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-31_20_17_01-15536349017889844599
2023/04/01 03:17:02 Job state: JOB_STATE_PENDING ...
2023/04/01 03:17:32 Job still running ...
2023/04/01 03:18:02 Job still running ...
2023/04/01 03:18:32 Job still running ...
2023/04/01 03:19:02 Job still running ...
2023/04/01 03:19:32 Job still running ...
2023/04/01 03:20:02 Job still running ...
2023/04/01 03:20:32 Job still running ...
2023/04/01 03:21:02 Job still running ...
2023/04/01 03:21:32 Job still running ...
2023/04/01 03:22:02 Job still running ...
2023/04/01 03:22:32 Job still running ...
2023/04/01 03:23:02 Job still running ...
2023/04/01 03:23:32 Job still running ...
2023/04/01 03:24:02 Job still running ...
2023/04/01 03:24:32 Job still running ...
2023/04/01 03:25:02 Job still running ...
2023/04/01 03:25:33 Job still running ...
2023/04/01 03:26:03 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-31_20_17_01-15536349017889844599 failed
--- FAIL: TestXLang_Partition (580.34s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3297.591s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680316304224421828
--- FAIL: TestBigQueryIO_BasicWriteRead (5.41s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42371 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@AMHjlqhAOC" is_bounded:BOUNDED windowing_strategy_id:"w0@AMHjlqhAOC"}} windowing_strategies:{key:"w0@AMHjlqhAOC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@AMHjlqhAOC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@AMHjlqhAOC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@AMHjlqhAOC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680316304224421828\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"AMHjlqhAOC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42371 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@AMHjlqhAOC" is_bounded:BOUNDED windowing_strategy_id:"w0@AMHjlqhAOC"}} windowing_strategies:{key:"w0@AMHjlqhAOC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@AMHjlqhAOC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@AMHjlqhAOC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@AMHjlqhAOC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680316304224421828\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"AMHjlqhAOC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 41 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc0003c7180})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc0003c7180})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001205c0?, 0xc0001b0230?}, {0x1137c73, 0x39}, {0xc0001d20c0?, 0xa9d780?, 0x1?}, {0xc0001a9650, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000120560?, 0xc0001b0230?}, {0xc00004c480, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0x7fc2e7cd1448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001a9650, 0xf}, {0xc00004c480, 0x52}, {0xeba2e0, 0xc000042190})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x1169b88)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.446s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.031s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5e416bc2927b6e986761f71088a88a292aae94c6e0f675f7b0b015c573e8f508
Deleted: sha256:3336f2d76185bce02bd7f859314cc664bfc2062c522571f2e21c1cf540903754
Deleted: sha256:c2da15843cd8b0f9a4afb725031bfe825c0d190827246b6dcf13653f28981843
Deleted: sha256:5350ebe0351ce42d88b3071f0a74d8d7c2626a03744ee6b318f73384a5ab18e9
Deleted: sha256:e3f0dfb943b9ff4404fef5cb94f0f5d5de508c6b3a78c57a44b42f2b5763c235
Deleted: sha256:2c4ace83738b54a0dba50e0d8302ff3141bbaa1ef0e0106f1cb1a44ff6b7be61
Deleted: sha256:53fe79acaecc659a1e31edb1ff70f113843fa06c2c3f08e2f49044b2feecca7a
Deleted: sha256:07920f95a6baec67dd6c1fcce02e2ddaf3475c6f5713cbd8f3b1570fd0d2d082
Deleted: sha256:b6f17efb6002a2e3643ee1692e1d4ce35ba89f43bc851788bbae10f2ba49de86
Deleted: sha256:54a7f303ded59c45f40b0eab7c8c667ecc0ee805577fc7a3983745085afd96f2
Deleted: sha256:c6a6b8948a753a003d532241d61f8f0b78277147c8ad7c0b2e0bf9e9fe7a2aff
Deleted: sha256:68a1f9b852776dfde4ae52e70f42d851689d764094c21c7128dc33705540d407
Deleted: sha256:b13e76080bd2522bf469cf0e55dac588d6f96ac7e36961078373bb473788cdc7
Deleted: sha256:886405c24eb893ef95e4f11b8f8f1486c1395617430d72f9f5b327431d00b0ce
Deleted: sha256:862294c2352f94ae9fea6f8d3944eff81149e1bf7b70b8500e0118f3d16463f7
Deleted: sha256:b9204e46ae9c633bec929df6f35de0a7252f03b1c3feea044bd64d49c32f8840
Deleted: sha256:a770c14f5b067e101b367b7d5351982606b77b376466d453a39aa42738025bed
Deleted: sha256:db6559908d924a38e3c5110f60cb4857cbe35328b5dcaadc9935ddf46812d102
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5e416bc2927b6e986761f71088a88a292aae94c6e0f675f7b0b015c573e8f508
  Associated tags:
 - 20230401-023056
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230401-023056].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5e416bc2927b6e986761f71088a88a292aae94c6e0f675f7b0b015c573e8f508].
$ rm -rf /tmp/tmp.iy92Zy9r30
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230401022030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230401022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230401022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4c4ca67b638fde6ef925dd86eefc453eb99c0149191f2f75d86cbd5ddbc89c79].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401022030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230401022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25890ddde3d17966bc2fedc64d24f91cb35dd5af3345699dae6f52800eed91cf].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2408145.
Stopping expansion service pid: 2408146.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 29s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1470

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1470/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331202059",
            "environmentId": "vSfNRSSjBubeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206"
      }
    ]
  },
  "name": "go-testxlang_partition-105",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/31 21:18:36 Submitted job: 2023-03-31_14_18_36-6649786612259679888
2023/03/31 21:18:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-31_14_18_36-6649786612259679888?project=apache-beam-testing
2023/03/31 21:18:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-31_14_18_36-6649786612259679888
2023/03/31 21:18:36 Job state: JOB_STATE_PENDING ...
2023/03/31 21:19:06 Job still running ...
2023/03/31 21:19:36 Job still running ...
2023/03/31 21:20:07 Job still running ...
2023/03/31 21:20:37 Job still running ...
2023/03/31 21:21:07 Job still running ...
2023/03/31 21:21:37 Job still running ...
2023/03/31 21:22:07 Job still running ...
2023/03/31 21:22:37 Job still running ...
2023/03/31 21:23:07 Job still running ...
2023/03/31 21:23:37 Job still running ...
2023/03/31 21:24:07 Job still running ...
2023/03/31 21:24:37 Job still running ...
2023/03/31 21:25:07 Job still running ...
2023/03/31 21:25:37 Job still running ...
2023/03/31 21:26:07 Job still running ...
2023/03/31 21:26:37 Job still running ...
2023/03/31 21:27:07 Job still running ...
2023/03/31 21:27:37 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-31_14_18_36-6649786612259679888 failed
--- FAIL: TestXLang_Partition (581.23s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3314.460s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680294776776692116
--- FAIL: TestBigQueryIO_BasicWriteRead (5.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33303 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@siQCISuVsw" is_bounded:BOUNDED windowing_strategy_id:"w0@siQCISuVsw"}} windowing_strategies:{key:"w0@siQCISuVsw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@siQCISuVsw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@siQCISuVsw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@siQCISuVsw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680294776776692116\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"siQCISuVsw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33303 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@siQCISuVsw" is_bounded:BOUNDED windowing_strategy_id:"w0@siQCISuVsw"}} windowing_strategies:{key:"w0@siQCISuVsw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@siQCISuVsw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@siQCISuVsw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@siQCISuVsw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680294776776692116\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"siQCISuVsw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc00017ad80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc00017ad80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000136340?, 0xc00040a050?}, {0x1137c31, 0x39}, {0xc0000ee0c0?, 0xa9d780?, 0x1?}, {0xc00011ac90, 0xf}, 0xc00054bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001362e0?, 0xc00040a050?}, {0xc00004ca20, 0x52}, {0x1?}, {0xc00054bea8, 0x2, 0xe79320?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011ac90, 0xf}, {0xc00004ca20, 0x52}, {0xeba2e0, 0xc0003fe0e8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006c29c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006c29c0, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.561s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.045s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cd22ea984b72fe45a3a06e63b33b09470006154bde32e17420001341a58ef48
Deleted: sha256:81b33aa42a66e542b2f3282f3bf4aceea76c85748476f9832c4da0df4140c7f4
Deleted: sha256:21aff367cb2c75376a4ec9ffae26c93f17036013203a8a4d35769ec5ae3950bd
Deleted: sha256:191a20be860b44d26121432e8c42efe43191e0c59ddf5909ea34fb37856101c0
Deleted: sha256:ee77855052beeed334b41f823eae7ddaa8ba10af569f6598c904683d84076035
Deleted: sha256:5fece8a9d27b5c6ddd1f4f5ecac975916fdd85fa921191ae0d458bf5510c9ff9
Deleted: sha256:bb20b63fe6a4a37c5b6182fb9df4887d56db96793dd4b6b182a6860e02d563e3
Deleted: sha256:e12d1f27bc2c78b88575979142a7576a585950473eda6ba988ebae4fcaf2da47
Deleted: sha256:fddb5440a9a3e3b4588abbf5e8b2e9b10adea9ab1381f8752508c910ed750284
Deleted: sha256:4bdd0e4deaff1ef2505aec00fe8dd9a31514459247fcf8df5f1eddd783fa112e
Deleted: sha256:5ca4f2fa3d39399f076abeaae8b057a22d6c9067c9b7b7a23fa8503fdfa5f347
Deleted: sha256:353c838cc8bd11dcda3e485146cb40b14c72ee52230516994ca869dc679097d4
Deleted: sha256:403ecce9c37f84718ac600341c5b28259a482a6e5fb55989e180a704f22d217c
Deleted: sha256:6bfb1b20acf56db0851c1361de599f3f5c345647b3534f2ffc93ff1e04b55129
Deleted: sha256:174158ee468f60521deac2fc9b498bc8eb1e9d61bd163ab579eb85034d268905
Deleted: sha256:614f19e4e2eb63b9161faec079726eb22c78a0f3c38bb520b06a8be8265c7e08
Deleted: sha256:8aaf23bec761761e4939be50289d64edc37df9582d0ad7c5bc9eee174140ac27
Deleted: sha256:aa8206ea77ce865bbe919c8bf9ba73b03b9165e997db5009c9c2d7ab77436ddc
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cd22ea984b72fe45a3a06e63b33b09470006154bde32e17420001341a58ef48
  Associated tags:
 - 20230331-203206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-203206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cd22ea984b72fe45a3a06e63b33b09470006154bde32e17420001341a58ef48].
$ rm -rf /tmp/tmp.zJaSlZ8caP
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331202059
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331202059]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331202059] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daba2bfb50fde61811037cc0378abf48f39cc8e3625be8f5306d128ceb2faa2].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331202059
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369
Deleted: sha256:a31de49416c0e3c62e80046135ebd6cbe9ad4abed81b97fd34a64abee79b6184
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331202059]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331202059] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef71ce40e5af37d89f9e53e80dde19ee2a6a4172c6ee904cb02115c5239ee369].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1711698.
Stopping expansion service pid: 1711699.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 58s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1469

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1469/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331142038",
            "environmentId": "ZDuIirgpAsbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103"
      }
    ]
  },
  "name": "go-testxlang_partition-0",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/31 15:16:11 Submitted job: 2023-03-31_08_16_10-3156489466031653127
2023/03/31 15:16:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-31_08_16_10-3156489466031653127?project=apache-beam-testing
2023/03/31 15:16:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-31_08_16_10-3156489466031653127
2023/03/31 15:16:11 Job state: JOB_STATE_PENDING ...
2023/03/31 15:16:41 Job still running ...
2023/03/31 15:17:11 Job still running ...
2023/03/31 15:17:41 Job still running ...
2023/03/31 15:18:11 Job still running ...
2023/03/31 15:18:41 Job still running ...
2023/03/31 15:19:11 Job still running ...
2023/03/31 15:19:41 Job still running ...
2023/03/31 15:20:11 Job still running ...
2023/03/31 15:20:41 Job still running ...
2023/03/31 15:21:11 Job still running ...
2023/03/31 15:21:41 Job still running ...
2023/03/31 15:22:11 Job still running ...
2023/03/31 15:22:41 Job still running ...
2023/03/31 15:23:11 Job still running ...
2023/03/31 15:23:41 Job still running ...
2023/03/31 15:24:12 Job still running ...
2023/03/31 15:24:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-31_08_16_10-3156489466031653127 failed
--- FAIL: TestXLang_Partition (552.43s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3211.157s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680273104319641543
--- FAIL: TestBigQueryIO_BasicWriteRead (4.63s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35909 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wOBWefAYyN" is_bounded:BOUNDED windowing_strategy_id:"w0@wOBWefAYyN"}} windowing_strategies:{key:"w0@wOBWefAYyN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wOBWefAYyN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wOBWefAYyN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wOBWefAYyN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680273104319641543\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wOBWefAYyN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35909 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wOBWefAYyN" is_bounded:BOUNDED windowing_strategy_id:"w0@wOBWefAYyN"}} windowing_strategies:{key:"w0@wOBWefAYyN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wOBWefAYyN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wOBWefAYyN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wOBWefAYyN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680273104319641543\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wOBWefAYyN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 7 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc0000e39c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc0000e39c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000524560?, 0xc000530000?}, {0x1137c31, 0x39}, {0xc00015c0c0?, 0xa9d780?, 0x1?}, {0xc00040b0b0, 0xf}, 0xc0000fdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000524500?, 0xc000530000?}, {0xc0000d4360, 0x52}, {0x1?}, {0xc0000fdea8, 0x2, 0x7f665c396df8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00040b0b0, 0xf}, {0xc0000d4360, 0x52}, {0xeba2e0, 0xc000522100})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000427a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000427a00, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.661s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:db5f7f923c27d96866125d672e72ef5f662f302c7f8d661312b7c2b02839e94f
Deleted: sha256:3bc68f0f2dad7e71ffd9deda6f48f01e0afe5072b95e85b1a19338157fcf3756
Deleted: sha256:5943f306b415d4d46912c5d790a0fb0500bdeac7598471bf3a2de3f8e21accb4
Deleted: sha256:205dcd6ef3696e0d6903130a2e3d6eeae8e26ee36b05e8a361f275f907c56d74
Deleted: sha256:d058698417a40448349016b0e588b3f6fcbc83d05baaad720c26e948716089e8
Deleted: sha256:6143eadf2ec32175804fa0c9d5feb10762511032bf95830781b502cc3e17013f
Deleted: sha256:ff4b68608208408c5e9adddb26264de4998e648ddc30d6f3649a19dd1a3a4b90
Deleted: sha256:191dbffbfa436eef1fd4551b40687b5486a7a2343ecb1d67ac64141df9468164
Deleted: sha256:45a40cffaee4aa1c301d95fd436bbbf78b9e1ffb8f60e4634d0c810954b677c4
Deleted: sha256:21cb2968ea52ee2cb8d98c6ebaa7ce651b2d75df71f278d36bdded94010fba55
Deleted: sha256:220c72e51454b265edb21d0ab03733276fd8187e5370a47a2fdb9c4fb2501800
Deleted: sha256:d0bc64d3bf4e9d43386ae8024b04022892ee5e7244062acd931a5eef95fe6609
Deleted: sha256:519b0a2d29f5a4bf430d13636b0fc1960f5e428c1254553f5d2f6d7cceaacad8
Deleted: sha256:93d4a4113cf61ec977ef3c2c080db1d37b77376f51b42ea81793eb289ba2dea7
Deleted: sha256:b74487a588b9a629873fd1ad435941ad83775ea16d12a8b9d146465c13ac0de8
Deleted: sha256:6de7025d7eabd0623b92b26c5e121c23a7b82f9022d247cda61054ccf7606ab9
Deleted: sha256:c1919eb4af3003d70d133ff04ca3cffa9e2e8efc75df316151387b1b0f8ffada
Deleted: sha256:27e0f995f8df14333a81e9ae6d8100db09aed2627d5850c6f2e5f95b998ecc6c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:db5f7f923c27d96866125d672e72ef5f662f302c7f8d661312b7c2b02839e94f
  Associated tags:
 - 20230331-143103
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-143103].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:db5f7f923c27d96866125d672e72ef5f662f302c7f8d661312b7c2b02839e94f].
$ rm -rf /tmp/tmp.SfNor7JDLd
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ee7b5528db646c04a78f1cd9c09c3f4224004a52f09a1aee033ba20a537f6817].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f86f02272fa0f01e87749fa73ea076fcd4ecb612fbfc82cce7b8b51f25fd9c00].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1182149.
Stopping expansion service pid: 1182150.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 10s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/27awqwzzaxmmg

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1468

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1468/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226"
      }
    ]
  },
  "name": "go-testxlang_partition-1",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/31 09:24:58 Submitted job: 2023-03-31_02_24_58-13777532435198033799
2023/03/31 09:24:58 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-31_02_24_58-13777532435198033799?project=apache-beam-testing
2023/03/31 09:24:58 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-31_02_24_58-13777532435198033799
2023/03/31 09:24:58 Job state: JOB_STATE_PENDING ...
2023/03/31 09:25:28 Job still running ...
2023/03/31 09:25:58 Job still running ...
2023/03/31 09:26:28 Job still running ...
2023/03/31 09:26:58 Job still running ...
2023/03/31 09:27:28 Job still running ...
2023/03/31 09:27:58 Job still running ...
2023/03/31 09:28:29 Job still running ...
2023/03/31 09:28:59 Job still running ...
2023/03/31 09:29:29 Job still running ...
2023/03/31 09:29:59 Job still running ...
2023/03/31 09:30:29 Job still running ...
2023/03/31 09:30:59 Job still running ...
2023/03/31 09:31:29 Job still running ...
2023/03/31 09:32:00 Job still running ...
2023/03/31 09:32:30 Job still running ...
2023/03/31 09:33:00 Job still running ...
2023/03/31 09:33:30 Job still running ...
2023/03/31 09:34:00 Job still running ...
2023/03/31 09:34:30 Job still running ...
2023/03/31 09:35:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-31_02_24_58-13777532435198033799 failed
--- FAIL: TestXLang_Partition (641.23s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3750.640s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680251583252631774
--- FAIL: TestBigQueryIO_BasicWriteRead (5.10s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZfrBESNLPu" is_bounded:BOUNDED windowing_strategy_id:"w0@ZfrBESNLPu"}} windowing_strategies:{key:"w0@ZfrBESNLPu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZfrBESNLPu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZfrBESNLPu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZfrBESNLPu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680251583252631774\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZfrBESNLPu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZfrBESNLPu" is_bounded:BOUNDED windowing_strategy_id:"w0@ZfrBESNLPu"}} windowing_strategies:{key:"w0@ZfrBESNLPu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZfrBESNLPu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZfrBESNLPu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZfrBESNLPu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680251583252631774\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZfrBESNLPu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 57 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc0005828c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc0005828c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fe0?, 0xc0000bc280?}, {0x1137c31, 0x39}, {0xc0000f00c0?, 0xa9d780?, 0x1?}, {0xc0003e6ca0, 0xf}, 0xc000199d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f80?, 0xc0000bc280?}, {0xc0003fc360, 0x52}, {0x1?}, {0xc000199ea8, 0x2, 0x7f43f12b1448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003e6ca0, 0xf}, {0xc0003fc360, 0x52}, {0xeba2e0, 0xc000042480})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003f91e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003f91e0, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.131s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:32e06b970b234ceb3ffb9eac1bd7a08bab5529d106cd4bca6c6988c3b4479aa4
Deleted: sha256:5f0a831ae400866929e8a996f98ebda20279d98f42ba27b5fad8660057380509
Deleted: sha256:67f3f557784afe39b684c308a858f3c178ff2a55da399bc849bc5b798b70b70e
Deleted: sha256:28457e0ae22a754f54510ea2c9176fc606efe3be942f73fd7de458d61d315de7
Deleted: sha256:8bf525cf58d1b50ba75c5eb3c3917adf9c6426bd3e3764cf2aec78be56493a51
Deleted: sha256:7e10d2f2fe585ec8d8f4b46ddc48fd1b64143a881242ac580de8ae8d9e39e553
Deleted: sha256:fcd0e1ab54cf3e2688f3b7d01c728982c36044e0a41111dec0ebee6d7f9a792f
Deleted: sha256:8817f95406bef2cb38294abdbef3a73a5459a9e9fe2b4b1fc0380e779f5ab409
Deleted: sha256:f8b1eb768f7680474216c000e5d8fb5452884d2224f0472ed40bab47e9535daf
Deleted: sha256:6aca0b0b363795fdac3f22ba910a56ebcacd51913802fbfee0dceed1f7bf173e
Deleted: sha256:be60e558ac957295fce39ed4cf9849c72bed12a9c8a17e2a080373cc1adeee74
Deleted: sha256:800218e3aed35445f3a6302dba458f22dbaf3df8cfa65e403d0a2c3682120e12
Deleted: sha256:d4e8b1b496bb2a35eb60a09a8afa9d203904c737b71e2779343ffd462c2f7610
Deleted: sha256:4cae6a5521d42b7f6dca15953ec8cc7d7914ebefbc92712738e0d0718a57028e
Deleted: sha256:0178cf1e8b5d7f85dc93ac1463823ab1f77c628384ca2e6ddeb761bbcd09aec8
Deleted: sha256:39009b778154d1ee3e4d65fc230ceac1814ad4655d99c1f3f7deca4d1123457b
Deleted: sha256:9099abcc878161021a0cb068345a0dca95234df5f7dc695425b353f35ff0d145
Deleted: sha256:cf35e9fb605799aea3163f27c4fc1b8d31b957d8010163c8e22ef12253a46589
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:32e06b970b234ceb3ffb9eac1bd7a08bab5529d106cd4bca6c6988c3b4479aa4
  Associated tags:
 - 20230331-083226
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-083226].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:32e06b970b234ceb3ffb9eac1bd7a08bab5529d106cd4bca6c6988c3b4479aa4].
$ rm -rf /tmp/tmp.buNVHfVfoC
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4adbdc972a64f1b3d3a4e6d468d56dbe84ac7a5ab1fbd263b38f3227171a4201].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f8897b448fc51a8137555e2d2c07c54745ab8906d884cbe18fee4509eb202197].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 943817.
Stopping expansion service pid: 943818.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 15m 17s
232 actionable tasks: 156 executed, 64 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1467

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1467/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-023115",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331022039",
            "environmentId": "iBEIKfyBmFbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-023115"
      }
    ]
  },
  "name": "go-testxlang_partition-223",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/31 03:20:21 Submitted job: 2023-03-30_20_20_20-6184854900672582211
2023/03/31 03:20:21 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-30_20_20_20-6184854900672582211?project=apache-beam-testing
2023/03/31 03:20:21 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-30_20_20_20-6184854900672582211
2023/03/31 03:20:21 Job state: JOB_STATE_PENDING ...
2023/03/31 03:20:51 Job still running ...
2023/03/31 03:21:21 Job still running ...
2023/03/31 03:21:51 Job still running ...
2023/03/31 03:22:21 Job still running ...
2023/03/31 03:22:51 Job still running ...
2023/03/31 03:23:22 Job still running ...
2023/03/31 03:23:52 Job still running ...
2023/03/31 03:24:22 Job still running ...
2023/03/31 03:24:52 Job still running ...
2023/03/31 03:25:22 Job still running ...
2023/03/31 03:25:52 Job still running ...
2023/03/31 03:26:22 Job still running ...
2023/03/31 03:26:52 Job still running ...
2023/03/31 03:27:22 Job still running ...
2023/03/31 03:27:52 Job still running ...
2023/03/31 03:28:22 Job still running ...
2023/03/31 03:28:52 Job still running ...
2023/03/31 03:29:22 Job still running ...
2023/03/31 03:29:52 Job still running ...
2023/03/31 03:30:22 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-30_20_20_20-6184854900672582211 failed
--- FAIL: TestXLang_Partition (641.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3542.419s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680229913621669466
--- FAIL: TestBigQueryIO_BasicWriteRead (4.98s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41693 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FKXZZCbUvf" is_bounded:BOUNDED windowing_strategy_id:"w0@FKXZZCbUvf"}} windowing_strategies:{key:"w0@FKXZZCbUvf" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FKXZZCbUvf" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FKXZZCbUvf" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FKXZZCbUvf" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680229913621669466\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FKXZZCbUvf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41693 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FKXZZCbUvf" is_bounded:BOUNDED windowing_strategy_id:"w0@FKXZZCbUvf"}} windowing_strategies:{key:"w0@FKXZZCbUvf" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FKXZZCbUvf" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FKXZZCbUvf" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FKXZZCbUvf" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680229913621669466\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FKXZZCbUvf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc000582740})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc000582740})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000412a40?, 0xc000117a40?}, {0x1137c31, 0x39}, {0xc00015e180?, 0xa9d780?, 0x1?}, {0xc00040eb40, 0xf}, 0xc00071fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004129e0?, 0xc000117a40?}, {0xc00041c420, 0x52}, {0x1?}, {0xc00071fea8, 0x2, 0x7efe759960b0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00040eb40, 0xf}, {0xc00041c420, 0x52}, {0xeba2e0, 0xc00040fe60})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00042cd00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00042cd00, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.013s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:96c01fea8963931c186f07b6fdd3ca7b4f88797e9a483eee87b9588ff0f1faa7
  Associated tags:
 - 20230331-023115
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-023115
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230331-023115].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:96c01fea8963931c186f07b6fdd3ca7b4f88797e9a483eee87b9588ff0f1faa7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331022039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1a238600373b0b328e095c6f50970b5929253490ffb19463496b1bc01106842]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230331022039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1a238600373b0b328e095c6f50970b5929253490ffb19463496b1bc01106842])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1a238600373b0b328e095c6f50970b5929253490ffb19463496b1bc01106842
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1a238600373b0b328e095c6f50970b5929253490ffb19463496b1bc01106842].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331022039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fe96190deec2fdad665e9b24bf0dfbdc9118f7588d4e4554beec77d90b6488e1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230331022039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fe96190deec2fdad665e9b24bf0dfbdc9118f7588d4e4554beec77d90b6488e1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fe96190deec2fdad665e9b24bf0dfbdc9118f7588d4e4554beec77d90b6488e1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fe96190deec2fdad665e9b24bf0dfbdc9118f7588d4e4554beec77d90b6488e1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 41s
232 actionable tasks: 156 executed, 64 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/7zfcx3lm3f3wm

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1466

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1466/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330211648",
            "environmentId": "OwxkiCfWSCbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-213631",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-213631"
      }
    ]
  },
  "name": "go-testxlang_partition-350",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/30 22:23:06 Submitted job: 2023-03-30_15_23_05-11505341082051172523
2023/03/30 22:23:06 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-30_15_23_05-11505341082051172523?project=apache-beam-testing
2023/03/30 22:23:06 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-30_15_23_05-11505341082051172523
2023/03/30 22:23:06 Job state: JOB_STATE_PENDING ...
2023/03/30 22:23:36 Job still running ...
2023/03/30 22:24:06 Job still running ...
2023/03/30 22:24:36 Job still running ...
2023/03/30 22:25:08 Job still running ...
2023/03/30 22:25:40 Job still running ...
2023/03/30 22:26:10 Job still running ...
2023/03/30 22:26:40 Job still running ...
2023/03/30 22:27:10 Job still running ...
2023/03/30 22:27:40 Job still running ...
2023/03/30 22:28:10 Job still running ...
2023/03/30 22:28:40 Job still running ...
2023/03/30 22:29:10 Job still running ...
2023/03/30 22:29:40 Job still running ...
2023/03/30 22:30:10 Job still running ...
2023/03/30 22:30:40 Job still running ...
2023/03/30 22:31:10 Job still running ...
2023/03/30 22:31:40 Job still running ...
2023/03/30 22:32:10 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-30_15_23_05-11505341082051172523 failed
--- FAIL: TestXLang_Partition (583.63s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3255.559s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680212315592077221
--- FAIL: TestBigQueryIO_BasicWriteRead (9.07s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37745 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@tlMNUbjigP" is_bounded:BOUNDED windowing_strategy_id:"w0@tlMNUbjigP"}} windowing_strategies:{key:"w0@tlMNUbjigP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@tlMNUbjigP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@tlMNUbjigP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@tlMNUbjigP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680212315592077221\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"tlMNUbjigP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37745 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@tlMNUbjigP" is_bounded:BOUNDED windowing_strategy_id:"w0@tlMNUbjigP"}} windowing_strategies:{key:"w0@tlMNUbjigP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@tlMNUbjigP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@tlMNUbjigP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@tlMNUbjigP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680212315592077221\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"tlMNUbjigP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 23 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc00060ed00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc00060ed00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6ba0?, 0xc000181b30?}, {0x1137c31, 0x39}, {0xc0001d20c0?, 0xa9d780?, 0x1?}, {0xc000042d00, 0xf}, 0xc000543d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6b40?, 0xc000181b30?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc000543ea8, 0x2, 0x7f9ef92ccb98?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d00, 0xf}, {0xc00004c4e0, 0x52}, {0xeba2e0, 0xc0001aa0b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00059d860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00059d860, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	12.131s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.068s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.072s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.088s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dcb9463a76fa14e6f87d5b5e07f63056070f55d4d1e2ed649952102aef6321a5
  Associated tags:
 - 20230330-213631
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-213631
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-213631].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dcb9463a76fa14e6f87d5b5e07f63056070f55d4d1e2ed649952102aef6321a5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330211648]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:09a2fc4d915d885e95438c79e04d38b7bf12cac88548fe1d7292082cf5f9fc79]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330211648] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:09a2fc4d915d885e95438c79e04d38b7bf12cac88548fe1d7292082cf5f9fc79])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:09a2fc4d915d885e95438c79e04d38b7bf12cac88548fe1d7292082cf5f9fc79
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:09a2fc4d915d885e95438c79e04d38b7bf12cac88548fe1d7292082cf5f9fc79].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330211648]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d1227e0f34c86f15a5cab71f09313ba1e3503b722d5af852d3f2a540e201effa]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330211648] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d1227e0f34c86f15a5cab71f09313ba1e3503b722d5af852d3f2a540e201effa])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d1227e0f34c86f15a5cab71f09313ba1e3503b722d5af852d3f2a540e201effa
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d1227e0f34c86f15a5cab71f09313ba1e3503b722d5af852d3f2a540e201effa].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 17m 38s
232 actionable tasks: 179 executed, 43 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1465

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1465/display/redirect?page=changes>

Changes:

[noreply] BigQueryHelpers: log statuses using PrettyString (#26037)


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330142041",
            "environmentId": "LbrXvlHbYHbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111"
      }
    ]
  },
  "name": "go-testxlang_partition-831",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/30 15:17:25 Submitted job: 2023-03-30_08_17_24-17754020599343629676
2023/03/30 15:17:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-30_08_17_24-17754020599343629676?project=apache-beam-testing
2023/03/30 15:17:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-30_08_17_24-17754020599343629676
2023/03/30 15:17:25 Job state: JOB_STATE_PENDING ...
2023/03/30 15:17:55 Job still running ...
2023/03/30 15:18:25 Job still running ...
2023/03/30 15:18:55 Job still running ...
2023/03/30 15:19:25 Job still running ...
2023/03/30 15:19:55 Job still running ...
2023/03/30 15:20:26 Job still running ...
2023/03/30 15:20:56 Job still running ...
2023/03/30 15:21:26 Job still running ...
2023/03/30 15:21:56 Job still running ...
2023/03/30 15:22:26 Job still running ...
2023/03/30 15:22:56 Job still running ...
2023/03/30 15:23:26 Job still running ...
2023/03/30 15:23:56 Job still running ...
2023/03/30 15:24:26 Job still running ...
2023/03/30 15:24:56 Job still running ...
2023/03/30 15:25:26 Job still running ...
2023/03/30 15:25:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-30_08_17_24-17754020599343629676 failed
--- FAIL: TestXLang_Partition (551.60s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3281.836s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680186708147748326
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45223 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KDSiucIcxW" is_bounded:BOUNDED windowing_strategy_id:"w0@KDSiucIcxW"}} windowing_strategies:{key:"w0@KDSiucIcxW" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KDSiucIcxW" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KDSiucIcxW" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KDSiucIcxW" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680186708147748326\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KDSiucIcxW"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45223 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KDSiucIcxW" is_bounded:BOUNDED windowing_strategy_id:"w0@KDSiucIcxW"}} windowing_strategies:{key:"w0@KDSiucIcxW" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KDSiucIcxW" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KDSiucIcxW" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KDSiucIcxW" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680186708147748326\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KDSiucIcxW"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc000156440})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc000156440})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003f09c0?, 0xc00049c050?}, {0x1137c31, 0x39}, {0xc00015e0c0?, 0xa9d780?, 0x1?}, {0xc0001375a0, 0xf}, 0xc000447d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003f0960?, 0xc00049c050?}, {0xc000414300, 0x52}, {0x1?}, {0xc000447ea8, 0x2, 0x7f008849e448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001375a0, 0xf}, {0xc000414300, 0x52}, {0xeba2e0, 0xc000042240})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0002feb60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0002feb60, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.476s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.045s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4f36669c68e2c733b62a39d6f350f257c0f447b7db504f6d7ec0c53753982f77
Deleted: sha256:46cafd05267de2828f6cb6b1cc0f5215d2c5b2f5f56208ee902175bcd89e4f1a
Deleted: sha256:8733dfaf614273d5b02894a58baf7286c8df46feac9f24de54a43dbd11e874cc
Deleted: sha256:1a0529505492171c520da0f10cf0406e0394c640eeed2d2716d41b0c8ba0f63e
Deleted: sha256:f25a43f8705bf1e909346f84fe599a3954a92ab66e1b9c878d70f229eb9b9e01
Deleted: sha256:be423d4693ea17e393c865eabc82b089def101d316194b5a7dc719463a39c739
Deleted: sha256:5f8c22ce8ad8692937ec1f872dd6c9ac2380829f4b849380dba3622fd0f6efcc
Deleted: sha256:7671d7006e2de0d8b682b886d67ba44f34c51b2a1875d096716f610d0a6122ca
Deleted: sha256:e59c0c93571234ef10adc6f418ea617dea43fd31b682b2eeb0620ff3c000a136
Deleted: sha256:f6ba226059f1882e65b00069e7e33ca96772c0a266d5484ef023c50aa1a6638c
Deleted: sha256:109fe08e5a4824aa87e472588f9a0eba0d9cc519213781b6e3b036d0f73b7ffc
Deleted: sha256:89c01ab84ab6aafb2dc5e922937221148f9a97488090059122eb95c28b5a0e83
Deleted: sha256:a05750c5665c5aaf2f7784a6f43fea0fcd659a6da6a69a4176626ca8846ea46d
Deleted: sha256:cfc366d4b747b41392901c56bc6bc98f20aef970c23574150fb5149e0dfa738f
Deleted: sha256:3be76a46dc6fc4a020f2b9c44f5434b8e9e662a487b72d3cdfea33a9c3887ded
Deleted: sha256:120562a9d743c54e45b5852b42ab34fd90ad4c57f3ac2c7cb3512656b1de99f8
Deleted: sha256:d3740ac93203ad785a03266119a748c8e49a7856b25c600b4c249dd0f979f722
Deleted: sha256:8d3e22e941da97b9812f67a3156bc5a7ac09cdb620c05ba5eaaffacef908891e
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4f36669c68e2c733b62a39d6f350f257c0f447b7db504f6d7ec0c53753982f77
  Associated tags:
 - 20230330-143111
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-143111].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4f36669c68e2c733b62a39d6f350f257c0f447b7db504f6d7ec0c53753982f77].
$ rm -rf /tmp/tmp.4mej1j9qTe
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2d03e40745e28943fd1fd3e5291b9475d7789a4fb1e8dac9e61a94047fc17c00].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b
Deleted: sha256:d5411deeba060a04b317e2047a35adcb90b2b24bb0aa5c5ac26097af7e643d31
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:746b9a10f20f35add4a90a2882dfa28239e8978d96dad088bdd1b41ca0c3784b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3635244.
Stopping expansion service pid: 3635245.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 10s
232 actionable tasks: 156 executed, 64 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1464

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1464/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-083100",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330082038",
            "environmentId": "JoDvvGzPgRbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-083100"
      }
    ]
  },
  "name": "go-testxlang_partition-72",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/30 09:18:36 Submitted job: 2023-03-30_02_18_35-4016725613291348115
2023/03/30 09:18:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-30_02_18_35-4016725613291348115?project=apache-beam-testing
2023/03/30 09:18:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-30_02_18_35-4016725613291348115
2023/03/30 09:18:36 Job state: JOB_STATE_PENDING ...
2023/03/30 09:19:06 Job still running ...
2023/03/30 09:19:37 Job still running ...
2023/03/30 09:20:07 Job still running ...
2023/03/30 09:20:37 Job still running ...
2023/03/30 09:21:07 Job still running ...
2023/03/30 09:21:37 Job still running ...
2023/03/30 09:22:07 Job still running ...
2023/03/30 09:22:37 Job still running ...
2023/03/30 09:23:07 Job still running ...
2023/03/30 09:23:37 Job still running ...
2023/03/30 09:24:07 Job still running ...
2023/03/30 09:24:37 Job still running ...
2023/03/30 09:25:07 Job still running ...
2023/03/30 09:25:37 Job still running ...
2023/03/30 09:26:07 Job still running ...
2023/03/30 09:26:37 Job still running ...
2023/03/30 09:27:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-30_02_18_35-4016725613291348115 failed
--- FAIL: TestXLang_Partition (551.45s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3364.761s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680165096396349494
--- FAIL: TestBigQueryIO_BasicWriteRead (4.23s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45929 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@QnBTfTPhbh" is_bounded:BOUNDED windowing_strategy_id:"w0@QnBTfTPhbh"}} windowing_strategies:{key:"w0@QnBTfTPhbh" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@QnBTfTPhbh" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@QnBTfTPhbh" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@QnBTfTPhbh" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680165096396349494\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"QnBTfTPhbh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45929 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@QnBTfTPhbh" is_bounded:BOUNDED windowing_strategy_id:"w0@QnBTfTPhbh"}} windowing_strategies:{key:"w0@QnBTfTPhbh" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@QnBTfTPhbh" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@QnBTfTPhbh" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@QnBTfTPhbh" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680165096396349494\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"QnBTfTPhbh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc0002ae1c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc0002ae1c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e660?, 0xc0000bc280?}, {0x1137c31, 0x39}, {0xc0000f00c0?, 0xa9d780?, 0x1?}, {0xc000654be0, 0xf}, 0xc000559d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e600?, 0xc0000bc280?}, {0xc00004ca20, 0x52}, {0x1?}, {0xc000559ea8, 0x2, 0xe79320?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000654be0, 0xf}, {0xc00004ca20, 0x52}, {0xeba2e0, 0xc000410228})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006429c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006429c0, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.259s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:33b952295f20768fcd71686f0854ca8d7d7b5358397dee5c603aea8711b484f7
  Associated tags:
 - 20230330-083100
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-083100
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-083100].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:33b952295f20768fcd71686f0854ca8d7d7b5358397dee5c603aea8711b484f7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:864b7edc0fb29aad37a383c74f9468d1f4c99d767ce6646ee239e901b97d18ae]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:864b7edc0fb29aad37a383c74f9468d1f4c99d767ce6646ee239e901b97d18ae])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:864b7edc0fb29aad37a383c74f9468d1f4c99d767ce6646ee239e901b97d18ae
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:864b7edc0fb29aad37a383c74f9468d1f4c99d767ce6646ee239e901b97d18ae].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83167e2ef009b3b6c765b3411125e9585f06050d189595d62a5557881d85b326]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83167e2ef009b3b6c765b3411125e9585f06050d189595d62a5557881d85b326])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83167e2ef009b3b6c765b3411125e9585f06050d189595d62a5557881d85b326
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83167e2ef009b3b6c765b3411125e9585f06050d189595d62a5557881d85b326].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 24s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1463

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1463/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-023102",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330022038",
            "environmentId": "jJRJIuEFARbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-023102"
      }
    ]
  },
  "name": "go-testxlang_partition-172",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/30 03:17:10 Submitted job: 2023-03-29_20_17_09-9962917435422812482
2023/03/30 03:17:10 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-29_20_17_09-9962917435422812482?project=apache-beam-testing
2023/03/30 03:17:10 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-29_20_17_09-9962917435422812482
2023/03/30 03:17:10 Job state: JOB_STATE_PENDING ...
2023/03/30 03:17:40 Job still running ...
2023/03/30 03:18:10 Job still running ...
2023/03/30 03:18:40 Job still running ...
2023/03/30 03:19:10 Job still running ...
2023/03/30 03:19:40 Job still running ...
2023/03/30 03:20:10 Job still running ...
2023/03/30 03:20:40 Job still running ...
2023/03/30 03:21:10 Job still running ...
2023/03/30 03:21:40 Job still running ...
2023/03/30 03:22:10 Job still running ...
2023/03/30 03:22:40 Job still running ...
2023/03/30 03:23:10 Job still running ...
2023/03/30 03:23:40 Job still running ...
2023/03/30 03:24:10 Job still running ...
2023/03/30 03:24:40 Job still running ...
2023/03/30 03:25:10 Job still running ...
2023/03/30 03:25:40 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-29_20_17_09-9962917435422812482 failed
--- FAIL: TestXLang_Partition (550.71s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3273.784s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680143500548757201
--- FAIL: TestBigQueryIO_BasicWriteRead (4.43s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35661 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@vzIlYfMpzy" is_bounded:BOUNDED windowing_strategy_id:"w0@vzIlYfMpzy"}} windowing_strategies:{key:"w0@vzIlYfMpzy" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@vzIlYfMpzy" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@vzIlYfMpzy" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@vzIlYfMpzy" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680143500548757201\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"vzIlYfMpzy"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35661 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@vzIlYfMpzy" is_bounded:BOUNDED windowing_strategy_id:"w0@vzIlYfMpzy"}} windowing_strategies:{key:"w0@vzIlYfMpzy" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@vzIlYfMpzy" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@vzIlYfMpzy" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@vzIlYfMpzy" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680143500548757201\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"vzIlYfMpzy"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc000027700})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc000027700})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040a7e0?, 0xc0004180a0?}, {0x1137c31, 0x39}, {0xc00015a0c0?, 0xa9d780?, 0x1?}, {0xc000042dc0, 0xf}, 0xc000031d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040a760?, 0xc0004180a0?}, {0xc00004c540, 0x52}, {0x1?}, {0xc000031ea8, 0x2, 0x7fca8ea02da8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042dc0, 0xf}, {0xc00004c540, 0x52}, {0xeba2e0, 0xc00040e200})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cc820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cc820, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.460s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68b5bd4d4a961de0e28da9a5d1f718c25f9071e603ef1088fdb290a33432b761
  Associated tags:
 - 20230330-023102
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-023102
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230330-023102].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68b5bd4d4a961de0e28da9a5d1f718c25f9071e603ef1088fdb290a33432b761].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2eadee6b5314e97d9eedceaefea44f3efca6aea86978e5639246e6067375f284]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230330022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2eadee6b5314e97d9eedceaefea44f3efca6aea86978e5639246e6067375f284])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2eadee6b5314e97d9eedceaefea44f3efca6aea86978e5639246e6067375f284
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2eadee6b5314e97d9eedceaefea44f3efca6aea86978e5639246e6067375f284].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7fc8352ec74652008a92a7a6111ec912b69b0d773848d6a618e18a0175f8ab96]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230330022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7fc8352ec74652008a92a7a6111ec912b69b0d773848d6a618e18a0175f8ab96])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7fc8352ec74652008a92a7a6111ec912b69b0d773848d6a618e18a0175f8ab96
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7fc8352ec74652008a92a7a6111ec912b69b0d773848d6a618e18a0175f8ab96].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 58s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1462

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1462/display/redirect>

Changes:


------------------------------------------
[...truncated 1.05 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329202042",
            "environmentId": "AYLbmnZeIKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248"
      }
    ]
  },
  "name": "go-testxlang_partition-908",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/29 21:19:42 Submitted job: 2023-03-29_14_19_41-12216656369559825711
2023/03/29 21:19:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-29_14_19_41-12216656369559825711?project=apache-beam-testing
2023/03/29 21:19:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-29_14_19_41-12216656369559825711
2023/03/29 21:19:42 Job state: JOB_STATE_PENDING ...
2023/03/29 21:20:12 Job still running ...
2023/03/29 21:20:42 Job still running ...
2023/03/29 21:21:12 Job still running ...
2023/03/29 21:21:42 Job still running ...
2023/03/29 21:22:12 Job still running ...
2023/03/29 21:22:42 Job still running ...
2023/03/29 21:23:12 Job still running ...
2023/03/29 21:23:42 Job still running ...
2023/03/29 21:24:12 Job still running ...
2023/03/29 21:24:43 Job still running ...
2023/03/29 21:25:13 Job still running ...
2023/03/29 21:25:43 Job still running ...
2023/03/29 21:26:13 Job still running ...
2023/03/29 21:26:43 Job still running ...
2023/03/29 21:27:13 Job still running ...
2023/03/29 21:27:43 Job still running ...
2023/03/29 21:28:13 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-29_14_19_41-12216656369559825711 failed
--- FAIL: TestXLang_Partition (551.10s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3313.353s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680122018409521107
--- FAIL: TestBigQueryIO_BasicWriteRead (4.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43937 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@kBTXfFlPPP" is_bounded:BOUNDED windowing_strategy_id:"w0@kBTXfFlPPP"}} windowing_strategies:{key:"w0@kBTXfFlPPP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@kBTXfFlPPP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@kBTXfFlPPP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@kBTXfFlPPP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680122018409521107\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"kBTXfFlPPP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43937 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@kBTXfFlPPP" is_bounded:BOUNDED windowing_strategy_id:"w0@kBTXfFlPPP"}} windowing_strategies:{key:"w0@kBTXfFlPPP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@kBTXfFlPPP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@kBTXfFlPPP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@kBTXfFlPPP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680122018409521107\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"kBTXfFlPPP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6c260, 0xc000021fc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c260, 0xc000021fc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003f0840?, 0xc000116280?}, {0x1137c31, 0x39}, {0xc00015e0c0?, 0xa9d780?, 0x1?}, {0xc0001376a0, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003f07e0?, 0xc000116280?}, {0xc000118840, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0xe79320?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001376a0, 0xf}, {0xc000118840, 0x52}, {0xeba2e0, 0xc000042328})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005a2d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005a2d00, 0x1169b48)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.559s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40a29a798544ee129e9ae693e5d2db576b8e24a7b14a0a947e15fa11f701e808
Deleted: sha256:1c69e31c7bef80717a12f00d84dd5c1327742a028fabe1c739af5fc29fe510a8
Deleted: sha256:9a349eefa4e9cb2a7c9610b031cb5e3e68561fa6bf0cf6c7a2299d4106724691
Deleted: sha256:37b76ce10e1ba9367fed02f0631bb982afb908f71d8d97c5a32e8fc6f06374e8
Deleted: sha256:a61a2aa626971a1bfafa20ef2262f6811c7ee8678077c0cfe627a652bb202bbc
Deleted: sha256:f51a1541a03299a6a0271b2139849c1db6ddb8034298d765ad6d5e8639cafc7b
Deleted: sha256:0f952e8da06e26c2dc6f5fd7df195a8d7c463582daf265f35ec927cbec9bac38
Deleted: sha256:2570e47f74f027de3e288a2f6d1d5133619de445fb369bc625d2883fc1685fa8
Deleted: sha256:e283d867654eeab0d330ef094ab0d29f13fe0f5d49be3f4d07cb4557eb3c8464
Deleted: sha256:16b1807ff79104d72540c650c2bcc15dee4c3aba14180735c50ae49ef9158084
Deleted: sha256:14f70d14559dcf6975d530698610a413a365267deb9fcffd1e2810a9b55ef54e
Deleted: sha256:ed7195a671fe8ac7b55504cab6de987a14dd68f41e17eb7efe65390e971b6563
Deleted: sha256:3b675ebbf3675e8253f62027b57514bd5bd4a0e3277aa76f96e379ab1ede12c7
Deleted: sha256:60ca525f128dcc2fce753e097ee169a06cc891e420cef7bcf884d422646c82ce
Deleted: sha256:6e56ce1966d6f78f8fe33be793d93cd016ef61515ef22172066d560ed89f65a5
Deleted: sha256:ca849fc1d4f429ddc26745a338c3576893fc51a367abc01b7186eab28dcf43e0
Deleted: sha256:900415ba91be73c13e21a8f705b54cfa0d49b839a5e4cf74ec9fb81c2cfd5fec
Deleted: sha256:aad3f59762abd00803aa0fc1424f4d9fb5922e0b1b6c90ac6ace37c0df8322b3
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40a29a798544ee129e9ae693e5d2db576b8e24a7b14a0a947e15fa11f701e808
  Associated tags:
 - 20230329-203248
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-203248].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40a29a798544ee129e9ae693e5d2db576b8e24a7b14a0a947e15fa11f701e808].
$ rm -rf /tmp/tmp.Vw0Repwxx9
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fcfde467af8ad90d3f69b2d52565763f7d6ad028b142ee7759ca6254c6b08b97].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:324e010a3c52cc9039f4afdf87b7f4d70c267b840900690d25a827e25b84739e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3142531.
Stopping expansion service pid: 3142532.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 30s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1461

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1461/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329142038",
            "environmentId": "UxTUFTiKWHbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204"
      }
    ]
  },
  "name": "go-testxlang_partition-803",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/29 15:20:35 Submitted job: 2023-03-29_08_20_35-6303183858765381735
2023/03/29 15:20:35 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-29_08_20_35-6303183858765381735?project=apache-beam-testing
2023/03/29 15:20:35 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-29_08_20_35-6303183858765381735
2023/03/29 15:20:35 Job state: JOB_STATE_PENDING ...
2023/03/29 15:21:05 Job still running ...
2023/03/29 15:21:35 Job still running ...
2023/03/29 15:22:05 Job still running ...
2023/03/29 15:22:35 Job still running ...
2023/03/29 15:23:05 Job still running ...
2023/03/29 15:23:35 Job still running ...
2023/03/29 15:24:06 Job still running ...
2023/03/29 15:24:36 Job still running ...
2023/03/29 15:25:06 Job still running ...
2023/03/29 15:25:36 Job still running ...
2023/03/29 15:26:06 Job still running ...
2023/03/29 15:26:36 Job still running ...
2023/03/29 15:27:06 Job still running ...
2023/03/29 15:27:36 Job still running ...
2023/03/29 15:28:06 Job still running ...
2023/03/29 15:28:36 Job still running ...
2023/03/29 15:29:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-29_08_20_35-6303183858765381735 failed
--- FAIL: TestXLang_Partition (550.83s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3420.502s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680100359488633967
--- FAIL: TestBigQueryIO_BasicWriteRead (4.67s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37915 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@kCgEvOoUcd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@kCgEvOoUcd"}}  windowing_strategies:{key:"w0@kCgEvOoUcd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@kCgEvOoUcd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@kCgEvOoUcd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@kCgEvOoUcd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680100359488633967\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"kCgEvOoUcd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37915 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@kCgEvOoUcd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@kCgEvOoUcd"}}  windowing_strategies:{key:"w0@kCgEvOoUcd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@kCgEvOoUcd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@kCgEvOoUcd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@kCgEvOoUcd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680100359488633967\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"kCgEvOoUcd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf71820, 0xc0004268c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf71820, 0xc0004268c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000400c20?, 0xc000117b30?}, {0x113df7e, 0x39}, {0xc00015e0c0?, 0xa9eec0?, 0x1?}, {0xc000422cb0, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000400bc0?, 0xc000117b30?}, {0xc000118840, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f0f48b865d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000422cb0, 0xf}, {0xc000118840, 0x52}, {0xebf2a0, 0xc000423fc0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005c29c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005c29c0, 0x116fe90)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.703s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.041s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:baaf3edfea010e50a0de5750898e66aceb2dd575178172bcca0d9d6ed04ed3c8
Deleted: sha256:4724e78b2526dbd26b7a14c4823205dfa68ee96382cb01bdc32ed75c2caeec1b
Deleted: sha256:80fb628d14f3c9aa98cc14335dc10dd4fa11f2fb98b1ac79281c1946e8720796
Deleted: sha256:60e698a5dd2e0fbae297bad57205b0b8f8ddc95c0ca31ab6e029f46d2318287f
Deleted: sha256:201ceeb1a9adffd89431ac789db1ae81dcc4f30889a470032af496583c17e8b8
Deleted: sha256:97cf28562512ff189cfa7d40b26ca357c3fc3d0c5348163a6151dededfd413e8
Deleted: sha256:4e5acc96c0755f23d2955a532b7afadefc5455649dbad527b5796119d4ce1eb7
Deleted: sha256:b5fef6366eed6f722f0be4875bfdc3ac958aa340b846221f741276a97f172d81
Deleted: sha256:a449954be4088daf1dfac722c2d496a3dfb7abbdb418dab5705757497a090bba
Deleted: sha256:b6c9049a8c39f0d20eb49a5712ec9241c33f396aa1c2e75e2506fa7db2b7fe74
Deleted: sha256:ac81697b3f8b9c4b68938dc9df716e3d86788d7af4ea06283a6d36ad065c17b0
Deleted: sha256:7e7ac86dd96bbb64649a463d77143963b41ee08ef421a48a4439f6e8ddc6d59d
Deleted: sha256:8de6ae42e55fc704e13dc3712c58bc6468ec4ec97ecf3a2f97da01253e0c0276
Deleted: sha256:466f49dc6bce5dd3480a92e4e0e1cca9b57fa954a029f78eb40773b8986d7ec7
Deleted: sha256:4203f6572068607d8fefda465d3d84f0071e105e0a419beedc8c33e4fd71f7fc
Deleted: sha256:c0219179823345a2bcd58f4066499691e053a8b7e149ec46183deee2d6a4b7a1
Deleted: sha256:540836f2b961c50ef1afcd4235ecaf5d60a79f22cfa6b6b0581f7137f7585aba
Deleted: sha256:f8837cb26dbd10e2507407e45d50f0ac1716e0f7f3e86950f4f940dd7a1b7532
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:baaf3edfea010e50a0de5750898e66aceb2dd575178172bcca0d9d6ed04ed3c8
  Associated tags:
 - 20230329-143204
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-143204].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:baaf3edfea010e50a0de5750898e66aceb2dd575178172bcca0d9d6ed04ed3c8].
$ rm -rf /tmp/tmp.roGkwuZUT4
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a750b8edbe2adc86a52ca7b7a7f77aab49eefb6941502c0bbeaf165b5ebcbeaa].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a70f604caa9225a947ea67cccd793c5a877f19cd04ef28d5b5c01dc977aa2bc5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2495814.
Stopping expansion service pid: 2495815.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 25s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1460

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1460/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329082029",
            "environmentId": "skNbtWukkWbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-083146",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-083146"
      }
    ]
  },
  "name": "go-testxlang_partition-36",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/29 09:18:58 Submitted job: 2023-03-29_02_18_57-16657939550964321550
2023/03/29 09:18:58 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-29_02_18_57-16657939550964321550?project=apache-beam-testing
2023/03/29 09:18:58 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-29_02_18_57-16657939550964321550
2023/03/29 09:18:58 Job state: JOB_STATE_PENDING ...
2023/03/29 09:19:28 Job still running ...
2023/03/29 09:19:58 Job still running ...
2023/03/29 09:20:28 Job still running ...
2023/03/29 09:20:58 Job still running ...
2023/03/29 09:21:28 Job still running ...
2023/03/29 09:21:58 Job still running ...
2023/03/29 09:22:28 Job still running ...
2023/03/29 09:22:58 Job still running ...
2023/03/29 09:23:28 Job still running ...
2023/03/29 09:23:58 Job still running ...
2023/03/29 09:24:28 Job still running ...
2023/03/29 09:24:58 Job still running ...
2023/03/29 09:25:29 Job still running ...
2023/03/29 09:25:59 Job still running ...
2023/03/29 09:26:29 Job still running ...
2023/03/29 09:26:59 Job still running ...
2023/03/29 09:27:29 Job still running ...
2023/03/29 09:27:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-29_02_18_57-16657939550964321550 failed
--- FAIL: TestXLang_Partition (580.51s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3361.168s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680078757503730946
--- FAIL: TestBigQueryIO_BasicWriteRead (4.79s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RoYtuXYMjT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RoYtuXYMjT"}}  windowing_strategies:{key:"w0@RoYtuXYMjT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RoYtuXYMjT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RoYtuXYMjT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RoYtuXYMjT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680078757503730946\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RoYtuXYMjT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RoYtuXYMjT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RoYtuXYMjT"}}  windowing_strategies:{key:"w0@RoYtuXYMjT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RoYtuXYMjT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RoYtuXYMjT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RoYtuXYMjT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680078757503730946\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RoYtuXYMjT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf71820, 0xc0001ccb40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf71820, 0xc0001ccb40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005a2580?, 0xc0005d0000?}, {0x113df7e, 0x39}, {0xc0001d20c0?, 0xa9eec0?, 0x1?}, {0xc000596d30, 0xf}, 0xc000033d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005a2520?, 0xc0005d0000?}, {0xc0005b6360, 0x52}, {0x1?}, {0xc000033ea8, 0x2, 0x7f2da834f448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000596d30, 0xf}, {0xc0005b6360, 0x52}, {0xebf2a0, 0xc000042190})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004bcb60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004bcb60, 0x116fe90)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.824s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d0fd9b1ddfc441703f1949b573b7267df661719f9f8dc74071c62049239037a
  Associated tags:
 - 20230329-083146
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-083146
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-083146].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d0fd9b1ddfc441703f1949b573b7267df661719f9f8dc74071c62049239037a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf21783bf63a97082d2d89594b2d77d8b5b77423ab038f85f10b75dd10adb496]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf21783bf63a97082d2d89594b2d77d8b5b77423ab038f85f10b75dd10adb496])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf21783bf63a97082d2d89594b2d77d8b5b77423ab038f85f10b75dd10adb496
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf21783bf63a97082d2d89594b2d77d8b5b77423ab038f85f10b75dd10adb496].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9829cd3c0c9921e63480b7f50c3a5d60576ca6e3eb133646115640d0aa40ffb8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9829cd3c0c9921e63480b7f50c3a5d60576ca6e3eb133646115640d0aa40ffb8])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9829cd3c0c9921e63480b7f50c3a5d60576ca6e3eb133646115640d0aa40ffb8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9829cd3c0c9921e63480b7f50c3a5d60576ca6e3eb133646115640d0aa40ffb8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 27s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1459

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1459/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329022036",
            "environmentId": "WFWTMoKrSmbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054"
      }
    ]
  },
  "name": "go-testxlang_partition-971",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/29 03:16:27 Submitted job: 2023-03-28_20_16_26-677333721022484550
2023/03/29 03:16:27 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-28_20_16_26-677333721022484550?project=apache-beam-testing
2023/03/29 03:16:27 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-28_20_16_26-677333721022484550
2023/03/29 03:16:27 Job state: JOB_STATE_PENDING ...
2023/03/29 03:16:57 Job still running ...
2023/03/29 03:17:27 Job still running ...
2023/03/29 03:17:57 Job still running ...
2023/03/29 03:18:27 Job still running ...
2023/03/29 03:18:57 Job still running ...
2023/03/29 03:19:27 Job still running ...
2023/03/29 03:19:57 Job still running ...
2023/03/29 03:20:27 Job still running ...
2023/03/29 03:21:00 Job still running ...
2023/03/29 03:21:30 Job still running ...
2023/03/29 03:22:00 Job still running ...
2023/03/29 03:22:30 Job still running ...
2023/03/29 03:23:00 Job still running ...
2023/03/29 03:23:30 Job still running ...
2023/03/29 03:24:00 Job still running ...
2023/03/29 03:24:30 Job still running ...
2023/03/29 03:25:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-28_20_16_26-677333721022484550 failed
--- FAIL: TestXLang_Partition (553.74s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.663s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680057092463848105
--- FAIL: TestBigQueryIO_BasicWriteRead (4.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34493 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@HIiHoUvpFh" is_bounded:BOUNDED windowing_strategy_id:"w0@HIiHoUvpFh"}} windowing_strategies:{key:"w0@HIiHoUvpFh" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@HIiHoUvpFh" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@HIiHoUvpFh" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@HIiHoUvpFh" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680057092463848105\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"HIiHoUvpFh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34493 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@HIiHoUvpFh" is_bounded:BOUNDED windowing_strategy_id:"w0@HIiHoUvpFh"}} windowing_strategies:{key:"w0@HIiHoUvpFh" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@HIiHoUvpFh" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@HIiHoUvpFh" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@HIiHoUvpFh" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680057092463848105\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"HIiHoUvpFh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 7 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0004b5fc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0004b5fc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001160e0?, 0xc0005be4b0?}, {0x113b23e, 0x39}, {0xc0000ee0c0?, 0xa9ea20?, 0x1?}, {0xc000472a60, 0xf}, 0xc0004cfd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000116040?, 0xc0005be4b0?}, {0xc00004c900, 0x52}, {0x1?}, {0xc0004cfea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000472a60, 0xf}, {0xc00004c900, 0x52}, {0xebcb60, 0xc00012a108})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.411s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:afcbc173c042d845d9019e858869e98433baf12fbea5ff828ada3ea71aa9a32e
Deleted: sha256:c779765edd4924bfe67c615265dd7a4dbb18c661bc6e13262b6c48aed5ce1e27
Deleted: sha256:d44bbd3066679177a8206ee89ea6c511220ffb60072cef32985c5ccdae6490f2
Deleted: sha256:bd42cddbb05446cef2bb27bbe5362dcdf1a1943dff325e60ac3f235310a5fe18
Deleted: sha256:f9e7670c1b28a07509bc57c46377cab0f5159a3936398e24509861b550f9c3e2
Deleted: sha256:aad37464560d07d09b0079bdaf1e6ba6c8a96a90f4338735012376fd1ce52ea9
Deleted: sha256:a21bfc96b03626d43268f8ac7965054cc7d94cac0b335f97c7c0849562a960b4
Deleted: sha256:c617ef7ac2c013bf489d6f4be9fc9974fe9d7b3c7fccea50540ef3cbb221cdd4
Deleted: sha256:6bf143c8f361bb31c156212f649e336665ca70ac7fa542d0d0ac653310b87371
Deleted: sha256:2c4cb4fc830a25a2c6a46a0797e3076d8cab4c17cf7cf7fbccd772bf6936f77a
Deleted: sha256:cbc2508a24b15508c1d4009e02fa10423f58db45abd215ab91732f65d8b92d22
Deleted: sha256:307b3c550970b43f0921516a489326661f936e14f0bb6608eaa20a49dc0bacab
Deleted: sha256:62b3f3913683dd5210b4781eda2d5d1e4f911951a5bfdd424518bedb7b3c0232
Deleted: sha256:241ea30c74a2e1ec1a5f4a8c9bc104ce0cac3e0f5f79658870e8b1b055eaf73f
Deleted: sha256:035817c323e1426d3448bf1d8fec5b5d5b31f99f0007565d375eeb63cc1aa200
Deleted: sha256:b36a5086a620c53255d5583dad86c252c43988e738f343304f0cb9539623abce
Deleted: sha256:33cf221b847b83a6a71eed4fad92931239b98eda62abfc6c24947588718986f1
Deleted: sha256:9ffe728936d0b7e59406d5402605edc8fae292304a836c888d79de413e6206ac
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:afcbc173c042d845d9019e858869e98433baf12fbea5ff828ada3ea71aa9a32e
  Associated tags:
 - 20230329-023054
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230329-023054].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:afcbc173c042d845d9019e858869e98433baf12fbea5ff828ada3ea71aa9a32e].
$ rm -rf /tmp/tmp.4QLJLRWgR1
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329022036
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230329022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6fbbb0ed2c5045ab8b3091ec4181d6ba6093e4ffd94a4fd06e1d3ce2d12b34f6].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329022036
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230329022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6762f89ab29259ed776894cf5f30588a8fefad94d43952864ae10d5af21b52f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1829887.
Stopping expansion service pid: 1829888.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 18s
232 actionable tasks: 162 executed, 58 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1458

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1458/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328202054",
            "environmentId": "qUamQeCeNwbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248"
      }
    ]
  },
  "name": "go-testxlang_partition-351",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/28 21:21:13 Submitted job: 2023-03-28_14_21_12-3695999268457143006
2023/03/28 21:21:13 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-28_14_21_12-3695999268457143006?project=apache-beam-testing
2023/03/28 21:21:13 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-28_14_21_12-3695999268457143006
2023/03/28 21:21:13 Job state: JOB_STATE_PENDING ...
2023/03/28 21:21:43 Job still running ...
2023/03/28 21:22:13 Job still running ...
2023/03/28 21:22:43 Job still running ...
2023/03/28 21:23:13 Job still running ...
2023/03/28 21:23:43 Job still running ...
2023/03/28 21:24:13 Job still running ...
2023/03/28 21:24:43 Job still running ...
2023/03/28 21:25:13 Job still running ...
2023/03/28 21:25:43 Job still running ...
2023/03/28 21:26:13 Job still running ...
2023/03/28 21:26:44 Job still running ...
2023/03/28 21:27:14 Job still running ...
2023/03/28 21:27:44 Job still running ...
2023/03/28 21:28:14 Job still running ...
2023/03/28 21:28:44 Job still running ...
2023/03/28 21:29:14 Job still running ...
2023/03/28 21:29:44 Job still running ...
2023/03/28 21:30:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-28_14_21_12-3695999268457143006 failed
--- FAIL: TestXLang_Partition (592.68s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3437.846s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680035620840784307
--- FAIL: TestBigQueryIO_BasicWriteRead (5.04s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42705 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rSrYjJgktk" is_bounded:BOUNDED windowing_strategy_id:"w0@rSrYjJgktk"}} windowing_strategies:{key:"w0@rSrYjJgktk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rSrYjJgktk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rSrYjJgktk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rSrYjJgktk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680035620840784307\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rSrYjJgktk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42705 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rSrYjJgktk" is_bounded:BOUNDED windowing_strategy_id:"w0@rSrYjJgktk"}} windowing_strategies:{key:"w0@rSrYjJgktk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rSrYjJgktk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rSrYjJgktk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rSrYjJgktk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1680035620840784307\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rSrYjJgktk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 5 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00029a700})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00029a700})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000419c80?, 0xc00042f770?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc000423360, 0xf}, 0xc0000efd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000419c20?, 0xc00042f770?}, {0xc0004b04e0, 0x52}, {0x1?}, {0xc0000efea8, 0x2, 0x7faa21dd1998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000423360, 0xf}, {0xc0004b04e0, 0x52}, {0xebcb60, 0xc000130fc0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000314340)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000314340, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.065s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bd2ad2d3286e9d9ebdd55a0ddb3dd0db9f07eab7bcb17b4eb1d7c2651ef143ff
Deleted: sha256:ffc1c6a1199efcea51bcf2b7e07c03b4f2d3bc9d3a25399b0ff9b223427aca9d
Deleted: sha256:7b3e50f92d3e0f35af96ddb40f5aa04e019f0804770d8e8e86a6f943659d4361
Deleted: sha256:f85a4d4d03c1f0799066c2ce4599b354c7c95d34af137ba695998d29761eedf6
Deleted: sha256:f491c1f7abd12e76cbeda5ac6ab5b27c53abbb02926c0b5536bc8f5f34032a7c
Deleted: sha256:f18d45b7cc161045a2e4ed031ad81edd40d4faae31374bc4a7bd87114f5eaf3f
Deleted: sha256:c67eb4a53be014caec21819ccb4dd940c822c1518985a82b6583b973d54d5345
Deleted: sha256:f5d4af28220635188d10147dbafbfd82092e22000dcf27b3cf546ea86b247aac
Deleted: sha256:347804ae0689d8bdeb4e141c91485d0f162b70fb60ba415ed080ed8ea995cfbd
Deleted: sha256:75b4ac1ebe9797f2880d1f00a3b21bb32e3f4e87ce60d99e41186a2c50b3cd3f
Deleted: sha256:53c2f6a1a26422f464a090c3695d6cc7c5508d2cb8e7a5bdd97db7522f53b88a
Deleted: sha256:11eb287577cd6159542ba55985b6cd0cf9733cf7810a64bba77ddfd98b72d159
Deleted: sha256:30b62e923bb00788ad9b95ba84424bbdb6bba9504084d742bccac9eccca02b8c
Deleted: sha256:673125c172e07a06257962e77ec3ab2891f1b15f00a221d74946074097c6d3ae
Deleted: sha256:0b92e3b35e238c080bc98bd456406f34c93c5c37d4aa14d614b4a3750e6f06e3
Deleted: sha256:e0a578e510e898536a63704278ebc1a68c9a7a4b025de67d4dd21734280e352d
Deleted: sha256:047a9346018bdf51e8a9e0ae5f99d596084edff690a2e8d435b625add16fc7f3
Deleted: sha256:e508b6af51427e2c6e9115967e62dec94c6bb481e278941570d98ede21b41395
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bd2ad2d3286e9d9ebdd55a0ddb3dd0db9f07eab7bcb17b4eb1d7c2651ef143ff
  Associated tags:
 - 20230328-203248
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-203248].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bd2ad2d3286e9d9ebdd55a0ddb3dd0db9f07eab7bcb17b4eb1d7c2651ef143ff].
$ rm -rf /tmp/tmp.qFADOpqVAA
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328202054
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328202054]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328202054] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b3772702b998ba89e95f0079a9c1123a8a276087e1fa305c99c00a7ea4aaf95d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328202054
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328202054]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328202054] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1d08fe2097560c5329f55deb6a5ca30601554e2df7acccd0b7f166f583bac7b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1488810.
Stopping expansion service pid: 1488811.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 28s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

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

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


beam_PostCommit_XVR_GoUsingJava_Dataflow - Build # 1457 - Aborted!

Posted by Apache Jenkins Server <je...@builds.apache.org>.
beam_PostCommit_XVR_GoUsingJava_Dataflow - Build # 1457 - Aborted:

Check console output at https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1457/ to view the results.

Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1456

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1456/display/redirect?page=changes>

Changes:

[noreply] BigQuery Storage Write API wrapper for Python SDK (#25685)


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328082045",
            "environmentId": "APzuHOUVoWbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121"
      }
    ]
  },
  "name": "go-testxlang_partition-955",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/28 09:16:26 Submitted job: 2023-03-28_02_16_25-11874950351200018049
2023/03/28 09:16:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-28_02_16_25-11874950351200018049?project=apache-beam-testing
2023/03/28 09:16:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-28_02_16_25-11874950351200018049
2023/03/28 09:16:26 Job state: JOB_STATE_PENDING ...
2023/03/28 09:16:56 Job still running ...
2023/03/28 09:17:26 Job still running ...
2023/03/28 09:17:56 Job still running ...
2023/03/28 09:18:26 Job still running ...
2023/03/28 09:18:56 Job still running ...
2023/03/28 09:19:26 Job still running ...
2023/03/28 09:19:57 Job still running ...
2023/03/28 09:20:27 Job still running ...
2023/03/28 09:20:57 Job still running ...
2023/03/28 09:21:27 Job still running ...
2023/03/28 09:21:57 Job still running ...
2023/03/28 09:22:27 Job still running ...
2023/03/28 09:22:57 Job still running ...
2023/03/28 09:23:27 Job still running ...
2023/03/28 09:23:57 Job still running ...
2023/03/28 09:24:27 Job still running ...
2023/03/28 09:24:57 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-28_02_16_25-11874950351200018049 failed
--- FAIL: TestXLang_Partition (551.25s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3211.006s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679992319907667271
--- FAIL: TestBigQueryIO_BasicWriteRead (4.87s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40591 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@WnmmvjQhGC" is_bounded:BOUNDED windowing_strategy_id:"w0@WnmmvjQhGC"}} windowing_strategies:{key:"w0@WnmmvjQhGC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@WnmmvjQhGC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@WnmmvjQhGC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@WnmmvjQhGC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679992319907667271\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"WnmmvjQhGC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40591 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@WnmmvjQhGC" is_bounded:BOUNDED windowing_strategy_id:"w0@WnmmvjQhGC"}} windowing_strategies:{key:"w0@WnmmvjQhGC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@WnmmvjQhGC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@WnmmvjQhGC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@WnmmvjQhGC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679992319907667271\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"WnmmvjQhGC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 52 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0003ed240})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0003ed240})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e6c0?, 0xc0000bc280?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc0003eb070, 0xf}, 0xc0005cbd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e660?, 0xc0000bc280?}, {0xc00059e3c0, 0x52}, {0x1?}, {0xc0005cbea8, 0x2, 0x7fd2f81d7d50?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003eb070, 0xf}, {0xc00059e3c0, 0x52}, {0xebcb60, 0xc00011e1c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000407a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000407a00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.905s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.030s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29fe172ca8daa2b71355262fc931fe8c83c713de792c2a9b689bde39462afe1b
Deleted: sha256:e4a1b37adcd6a0a0fd166e4f997d1c3c10f281309974ab17ba1c51bbf384993d
Deleted: sha256:e16d3cc8803558103c560677778fee79dcc46404936b58d9649551552244c1a0
Deleted: sha256:9d8991e298c609630c691e28d70cd7a88895a682c8d84a9078a53b5c0ac6e904
Deleted: sha256:8d0261af76fca811dcd94038ecdfa71bbc030fbad19601e16bf10a6c7fe28479
Deleted: sha256:6791cbc61e9528dedce94e55a7a88b22e0cb4a037ce59d4a57e3a8eadaa7d94f
Deleted: sha256:0db42504370501ac79100b7c3f256db392bdc5398f0370c65927cdb712f7cc6b
Deleted: sha256:3d0b69051ca0f83fc301e8df72d1dbf2868a64f0cb98e57c9c4ca3db004913cc
Deleted: sha256:0c142950a5e87b6e1b87d07c9a00ff508a4619d18d66665a80cdc0b6cfb821d5
Deleted: sha256:24d25359216e1c3b29154e50798abba4e11a0b67f805235c2075f4675cecbf3e
Deleted: sha256:375ab8bbbafa8775b99e73828a0f4f4ee806617be53ff41297b63607c4ff3c9a
Deleted: sha256:03f291b51609d09b8589b55e43bfd9240caa7b5e2aaeed1ec867a12c43fd1378
Deleted: sha256:400d025d3fd48820b07b8348bc6f7dfcd0ca90788dfb62dc0d5c32647c6477a1
Deleted: sha256:d559e8ab42aca1f9ce93f73f314a76ea64deaf482602573bcc9685f06dbbe057
Deleted: sha256:cd23ba28f749fb59a3a7ff283a51883c5f51a1cbdc83be943dd8369d367e5911
Deleted: sha256:07a44ee2f4ae401c2edb097c1a4c33b26dd0afe941bdbd28393d15b09e6df87e
Deleted: sha256:e0e3098fafd5cc5766a8bbac1dea753f035afa4ee39498b3e343eaf1f3d9fece
Deleted: sha256:4f033e8f642260da94b64910afdff8e55ecaf1c113f7c3264f453094155bc393
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29fe172ca8daa2b71355262fc931fe8c83c713de792c2a9b689bde39462afe1b
  Associated tags:
 - 20230328-083121
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-083121].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29fe172ca8daa2b71355262fc931fe8c83c713de792c2a9b689bde39462afe1b].
$ rm -rf /tmp/tmp.6jGBHeEHzy
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d3cadd2d9046c8b91fe9868819e40c8deff6062cf3df8f14728ec178c82f45].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:077e6065bd5b24bc65f447316bd6a53df710e13cb3f71997b402ccd418e4f87f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1165797.
Stopping expansion service pid: 1165798.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 9s
232 actionable tasks: 164 executed, 56 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1455

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1455/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328022050",
            "environmentId": "UKYLRvJWIXbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152"
      }
    ]
  },
  "name": "go-testxlang_partition-630",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/28 03:18:28 Submitted job: 2023-03-27_20_18_28-15853063071008360952
2023/03/28 03:18:28 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-27_20_18_28-15853063071008360952?project=apache-beam-testing
2023/03/28 03:18:28 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-27_20_18_28-15853063071008360952
2023/03/28 03:18:29 Job state: JOB_STATE_PENDING ...
2023/03/28 03:18:59 Job still running ...
2023/03/28 03:19:29 Job still running ...
2023/03/28 03:19:59 Job still running ...
2023/03/28 03:20:29 Job still running ...
2023/03/28 03:20:59 Job still running ...
2023/03/28 03:21:29 Job still running ...
2023/03/28 03:21:59 Job still running ...
2023/03/28 03:22:29 Job still running ...
2023/03/28 03:22:59 Job still running ...
2023/03/28 03:23:29 Job still running ...
2023/03/28 03:23:59 Job still running ...
2023/03/28 03:24:29 Job still running ...
2023/03/28 03:24:59 Job still running ...
2023/03/28 03:25:29 Job still running ...
2023/03/28 03:25:59 Job still running ...
2023/03/28 03:26:29 Job still running ...
2023/03/28 03:26:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-27_20_18_28-15853063071008360952 failed
--- FAIL: TestXLang_Partition (550.91s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3303.831s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679970749211689752
--- FAIL: TestBigQueryIO_BasicWriteRead (4.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38607 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@UKDcwjseBm" is_bounded:BOUNDED windowing_strategy_id:"w0@UKDcwjseBm"}} windowing_strategies:{key:"w0@UKDcwjseBm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@UKDcwjseBm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@UKDcwjseBm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@UKDcwjseBm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679970749211689752\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"UKDcwjseBm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38607 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@UKDcwjseBm" is_bounded:BOUNDED windowing_strategy_id:"w0@UKDcwjseBm"}} windowing_strategies:{key:"w0@UKDcwjseBm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@UKDcwjseBm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@UKDcwjseBm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@UKDcwjseBm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679970749211689752\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"UKDcwjseBm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0000b1d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0000b1d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169120?, 0xc000138280?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc00041acb0, 0xf}, 0xc0000f1d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001690c0?, 0xc000138280?}, {0xc0003f83c0, 0x52}, {0x1?}, {0xc0000f1ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00041acb0, 0xf}, {0xc0003f83c0, 0x52}, {0xebcb60, 0xc0001304e8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004231e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004231e0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.602s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.029s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:70f3cf41ce413fd3a23536970b300da103d3f811a6b27790f2ee7f68914da45b
Deleted: sha256:35aa67d8d7819e6766d22dd0f5cb615a2eb5f3a35fb972266455a281089dc304
Deleted: sha256:6d3322ea32a49a739a70ce9257f29a1249712e644105eacd8fa308e81b67cd19
Deleted: sha256:56ddddabf2cd3b972b8724df0ba5c7a1116752400367a1f8813c38e1011a0c2a
Deleted: sha256:bf4f00be97b1a6f22166c98478ddd9a3b40a6283bbcb16df9fc97478f639de1b
Deleted: sha256:87ec8730449a8f1f6f3510b09bc075a1e417a4f1aace5d97a03aef6fa07cec27
Deleted: sha256:e6e25f8efc0c32470cd2aa808d331029410441788aaedace7e59bb70cf091c1f
Deleted: sha256:71227a5563fd8c4351f9037924ef3d4cbc063610cdf7b8c95d8d3d6cb4cb69ec
Deleted: sha256:5cd599ce0c9e5ce11568cd87422e561db5a90fd8966e7e3ce79bf7064c243b38
Deleted: sha256:628d2d2f87c91168dcc7e5bff091e904fae7e3d0ca513898a1a389bcdba140c2
Deleted: sha256:801d56332ded2e6d126424e8d833b06613a6e323cee24687d1e96e788deaf1eb
Deleted: sha256:550bba1562254a5827402336161ffffc4174d70833255aac38fde4c4c3ae49b2
Deleted: sha256:f2376c27269d7655975c95366137060a50601a2ee9361bedbff768bce4b32b16
Deleted: sha256:b4c455932be21eafd849c9138be19fb7c864799e3698f94029ee6bc39ad91693
Deleted: sha256:7baf698e3e1ecbe0689b06ab0fed782be82ba134c529b65ae612b8b29fd6e2b4
Deleted: sha256:ac5459209fd33b45819f85c77bfa843c0d06b4df3dbde120dd477377ca1e5d2d
Deleted: sha256:8485648ac28569c498e790b3217cff71c40e8f0219e661465b6d3464f3105a60
Deleted: sha256:5648a2ae830a4b6aebb65d072f50026ee1ebfcd0b9d717307dafa3db3484f957
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:70f3cf41ce413fd3a23536970b300da103d3f811a6b27790f2ee7f68914da45b
  Associated tags:
 - 20230328-023152
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230328-023152].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:70f3cf41ce413fd3a23536970b300da103d3f811a6b27790f2ee7f68914da45b].
$ rm -rf /tmp/tmp.9I7RThmm6X
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328022050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328022050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230328022050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fede81652d1c2d17e0ca79a59e03e67d16847e2f788aeaf54923764e9f0bf468].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328022050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328022050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230328022050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5d848e561df45f2c12dc3c5f843850bb4399c9494a48d7ae646ba521b5978a4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 678284.
Stopping expansion service pid: 678285.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 14s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1454

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1454/display/redirect?page=changes>

Changes:

[noreply] Fix tfhub example + instructions (#25995)


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327202028",
            "environmentId": "rzxbwPKuKKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059"
      }
    ]
  },
  "name": "go-testxlang_partition-805",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/27 21:17:07 Submitted job: 2023-03-27_14_17_06-11360846404271470334
2023/03/27 21:17:07 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-27_14_17_06-11360846404271470334?project=apache-beam-testing
2023/03/27 21:17:07 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-27_14_17_06-11360846404271470334
2023/03/27 21:17:07 Job state: JOB_STATE_PENDING ...
2023/03/27 21:17:37 Job still running ...
2023/03/27 21:18:07 Job still running ...
2023/03/27 21:18:37 Job still running ...
2023/03/27 21:19:07 Job still running ...
2023/03/27 21:19:37 Job still running ...
2023/03/27 21:20:07 Job still running ...
2023/03/27 21:20:37 Job still running ...
2023/03/27 21:21:07 Job still running ...
2023/03/27 21:21:37 Job still running ...
2023/03/27 21:22:08 Job still running ...
2023/03/27 21:22:38 Job still running ...
2023/03/27 21:23:08 Job still running ...
2023/03/27 21:23:38 Job still running ...
2023/03/27 21:24:08 Job still running ...
2023/03/27 21:24:38 Job still running ...
2023/03/27 21:25:08 Job still running ...
2023/03/27 21:25:38 Job still running ...
2023/03/27 21:26:08 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-27_14_17_06-11360846404271470334 failed
--- FAIL: TestXLang_Partition (581.20s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3307.215s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679949094547628127
--- FAIL: TestBigQueryIO_BasicWriteRead (4.66s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42475 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NFlOZzecPz" is_bounded:BOUNDED windowing_strategy_id:"w0@NFlOZzecPz"}} windowing_strategies:{key:"w0@NFlOZzecPz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NFlOZzecPz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NFlOZzecPz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NFlOZzecPz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679949094547628127\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NFlOZzecPz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42475 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NFlOZzecPz" is_bounded:BOUNDED windowing_strategy_id:"w0@NFlOZzecPz"}} windowing_strategies:{key:"w0@NFlOZzecPz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NFlOZzecPz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NFlOZzecPz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NFlOZzecPz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679949094547628127\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NFlOZzecPz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000157580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000157580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000536680?, 0xc00054a000?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc000610c90, 0xf}, 0xc00064fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000536620?, 0xc00054a000?}, {0xc00004c540, 0x52}, {0x1?}, {0xc00064fea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000610c90, 0xf}, {0xc00004c540, 0x52}, {0xebcb60, 0xc000538138})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000403040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000403040, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.694s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.027s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4841cf212b8efa6b53b5c9f0ee8bba21c5be00ff09b984b217d2bed236dffa62
Deleted: sha256:6641830682abb6ee7775b10dd39254cdeee2be91e0eae6b150898b6bdbb04e5e
Deleted: sha256:d3ef2b5672a33f43353ccd86fdb6ef5812b74d5332984191deef65ed83190560
Deleted: sha256:0d0286445558894770d375e9922b90ced9dae18af068fb275227b28c8b14a412
Deleted: sha256:893bf961ee7057130c4166c93b78b30393e3c6f8d5300d8662d7b1c1e1669080
Deleted: sha256:251917ecf2447a42419da0859a0ea9904f6e94b87ca03e50c388e0af03c1e5e9
Deleted: sha256:ec7f30454124a596a0b4a6a67aa74bd0f2392aecbb0ef521a3009940fc32042e
Deleted: sha256:0c30d0a32006c57a168efdc34cd3c577f4a3991144a7001541e54061ea4ee68d
Deleted: sha256:1a909aa5bc7db1849e8ed1bb1f1dcdda67fae3af851c6b03feb2dea5c3b02ff5
Deleted: sha256:cf381b38283d0dbce7976b9d788d64d3e18062a7a0ae8332d3d6348734e3fc87
Deleted: sha256:27e693a83191ec64fd8f5bc7b1d419d3ed380773c5a5bd4fb12484d93c315a20
Deleted: sha256:953b570a9177788d334cfd8ae1bd37e0ee1056f4b52e40519ca8f894ba108ba2
Deleted: sha256:45efe309e75b60c2adc2273da334b158075d83cdfe7e73b23617b0233d1b08fa
Deleted: sha256:4fec942a90d66d62b145e50781dbe0b3e987184b6c37ff49f33cee8f2a652b9e
Deleted: sha256:5225f221955e5e12ac3b38f441b7d02d397f609d5cf86663cfe908de104e0570
Deleted: sha256:d0977ece4ce43d9f9a4cf5fbd847f04735997cab27ce9c292ff4072f8f1e0b53
Deleted: sha256:1b4cb4c5169a4481f83c7a1a962e5011be9a3dc06dd418f75f056f9ea5ee539e
Deleted: sha256:475aa81007ed0e16b87b67c7a83babce91631ade12b3cd45b940d7230f557364
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4841cf212b8efa6b53b5c9f0ee8bba21c5be00ff09b984b217d2bed236dffa62
  Associated tags:
 - 20230327-203059
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-203059].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4841cf212b8efa6b53b5c9f0ee8bba21c5be00ff09b984b217d2bed236dffa62].
$ rm -rf /tmp/tmp.iEf3ASvTdd
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327202028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327202028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327202028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6dca2c964caa61defcc34e56cff27176fe146af62032c7ce4c963fd5f22cbed5].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327202028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327202028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327202028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4ca21f7757fc8319501aa0fd4a26b17abe5d511ca22110df9328e83cf3444c8c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 371233.
Stopping expansion service pid: 371234.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 36s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1453

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1453/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-143100",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327142038",
            "environmentId": "aykFDzIdDHbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-143100"
      }
    ]
  },
  "name": "go-testxlang_partition-970",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/27 15:17:45 Submitted job: 2023-03-27_08_17_45-13247880786544831742
2023/03/27 15:17:45 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-27_08_17_45-13247880786544831742?project=apache-beam-testing
2023/03/27 15:17:45 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-27_08_17_45-13247880786544831742
2023/03/27 15:17:45 Job state: JOB_STATE_PENDING ...
2023/03/27 15:18:15 Job still running ...
2023/03/27 15:18:45 Job still running ...
2023/03/27 15:19:16 Job still running ...
2023/03/27 15:19:46 Job still running ...
2023/03/27 15:20:16 Job still running ...
2023/03/27 15:20:46 Job still running ...
2023/03/27 15:21:16 Job still running ...
2023/03/27 15:21:46 Job still running ...
2023/03/27 15:22:16 Job still running ...
2023/03/27 15:22:46 Job still running ...
2023/03/27 15:23:16 Job still running ...
2023/03/27 15:23:46 Job still running ...
2023/03/27 15:24:16 Job still running ...
2023/03/27 15:24:46 Job still running ...
2023/03/27 15:25:16 Job still running ...
2023/03/27 15:25:46 Job still running ...
2023/03/27 15:26:16 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-27_08_17_45-13247880786544831742 failed
--- FAIL: TestXLang_Partition (553.90s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3314.095s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679927495803492291
--- FAIL: TestBigQueryIO_BasicWriteRead (4.42s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45729 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zbhYHLokfP" is_bounded:BOUNDED windowing_strategy_id:"w0@zbhYHLokfP"}} windowing_strategies:{key:"w0@zbhYHLokfP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zbhYHLokfP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zbhYHLokfP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zbhYHLokfP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679927495803492291\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zbhYHLokfP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45729 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zbhYHLokfP" is_bounded:BOUNDED windowing_strategy_id:"w0@zbhYHLokfP"}} windowing_strategies:{key:"w0@zbhYHLokfP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zbhYHLokfP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zbhYHLokfP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zbhYHLokfP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679927495803492291\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zbhYHLokfP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 56 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0001ceb00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0001ceb00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7280?, 0xc000416050?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000403020, 0xf}, 0xc00015fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7220?, 0xc000416050?}, {0xc000138300, 0x52}, {0x1?}, {0xc00015fea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000403020, 0xf}, {0xc000138300, 0x52}, {0xebcb60, 0xc0001241c8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582ea0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.457s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f6049b1ddde3a061adabf69d79c47af650941b7d4d4071cb92fa21ceab6d089
  Associated tags:
 - 20230327-143100
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-143100
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-143100].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f6049b1ddde3a061adabf69d79c47af650941b7d4d4071cb92fa21ceab6d089].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7c26e192089e7535b0a8da6296ac3ecb8ebdab127a00e3c5bbe5f3505b1ce026]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7c26e192089e7535b0a8da6296ac3ecb8ebdab127a00e3c5bbe5f3505b1ce026])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7c26e192089e7535b0a8da6296ac3ecb8ebdab127a00e3c5bbe5f3505b1ce026
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7c26e192089e7535b0a8da6296ac3ecb8ebdab127a00e3c5bbe5f3505b1ce026].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d49830e67dc9a8ef1fcac53dd4d359dca81176bcfb531e1f9a2ace2fc0511340]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d49830e67dc9a8ef1fcac53dd4d359dca81176bcfb531e1f9a2ace2fc0511340])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d49830e67dc9a8ef1fcac53dd4d359dca81176bcfb531e1f9a2ace2fc0511340
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d49830e67dc9a8ef1fcac53dd4d359dca81176bcfb531e1f9a2ace2fc0511340].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 35s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1452

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1452/display/redirect>

Changes:


------------------------------------------
[...truncated 1.05 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147"
      }
    ]
  },
  "name": "go-testxlang_partition-828",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/27 09:17:28 Submitted job: 2023-03-27_02_17_27-13153756639286056615
2023/03/27 09:17:28 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-27_02_17_27-13153756639286056615?project=apache-beam-testing
2023/03/27 09:17:28 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-27_02_17_27-13153756639286056615
2023/03/27 09:17:28 Job state: JOB_STATE_PENDING ...
2023/03/27 09:17:58 Job still running ...
2023/03/27 09:18:28 Job still running ...
2023/03/27 09:18:58 Job still running ...
2023/03/27 09:19:28 Job still running ...
2023/03/27 09:19:58 Job still running ...
2023/03/27 09:20:28 Job still running ...
2023/03/27 09:20:58 Job still running ...
2023/03/27 09:21:28 Job still running ...
2023/03/27 09:21:58 Job still running ...
2023/03/27 09:22:28 Job still running ...
2023/03/27 09:22:58 Job still running ...
2023/03/27 09:23:29 Job still running ...
2023/03/27 09:23:59 Job still running ...
2023/03/27 09:24:29 Job still running ...
2023/03/27 09:24:59 Job still running ...
2023/03/27 09:25:29 Job still running ...
2023/03/27 09:25:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-27_02_17_27-13153756639286056615 failed
--- FAIL: TestXLang_Partition (550.45s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3245.026s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679905947440812860
--- FAIL: TestBigQueryIO_BasicWriteRead (4.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34001 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mUdcxYBUnl" is_bounded:BOUNDED windowing_strategy_id:"w0@mUdcxYBUnl"}} windowing_strategies:{key:"w0@mUdcxYBUnl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mUdcxYBUnl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mUdcxYBUnl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mUdcxYBUnl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679905947440812860\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mUdcxYBUnl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34001 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mUdcxYBUnl" is_bounded:BOUNDED windowing_strategy_id:"w0@mUdcxYBUnl"}} windowing_strategies:{key:"w0@mUdcxYBUnl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mUdcxYBUnl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mUdcxYBUnl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mUdcxYBUnl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679905947440812860\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mUdcxYBUnl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 23 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000278100})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000278100})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000408ea0?, 0xc000135770?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000410ca0, 0xf}, 0xc000567d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000408e40?, 0xc000135770?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc000567ea8, 0x2, 0x7f03f5c9b9e8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000410ca0, 0xf}, {0xc00004ca80, 0x52}, {0xebcb60, 0xc000411fb0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103a00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.871s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.041s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dcaa1b6ecfd0d2388b7e9c78ade199900e4c67320957ce0289d8df0a0f291196
Deleted: sha256:5e9107f3c65e047f3566e01d0259cad00535fa06f3199216ad58018a18378133
Deleted: sha256:428cddc7395857883813579a0637ee53d0174108e953eea6933e57d003b3786a
Deleted: sha256:14869f32b07f3c80c62fe7fe95bdd020265409ffd152b70c891ec18c56918f58
Deleted: sha256:4fd3e6b2a2549f8272b0fcd7bb055e9357d0c37ff18aeff7346accccb06d4d4a
Deleted: sha256:fcf1b433f8441c00956adc2764a029ac3ef59715c3d3aff84ccc5b342be090e5
Deleted: sha256:7ff1f816c0d31382932defe5d815c84fd311fe6a24ab82485b298c6b6772b2c8
Deleted: sha256:0774b0abe7cd8ca67a03b30948f4bc2717adcb0a4df76b20bfbd9acd31b49c21
Deleted: sha256:8bda9fb65cf258c2a71b05cbd2e2bf9e8c364779ea79f1f876c13be897edf8d6
Deleted: sha256:a1f8832f42c073350ddd9e41963d6152f650d29e411d75e4a8698a27711f6615
Deleted: sha256:4d7e6e8c1912d2e5558840318c0e2ca2dbea2dd2d006ded9ea7c7e8d49e2d653
Deleted: sha256:3422ca954b1a97dcd395f664408ce0fca2ece2d927bd6d4c6f685ebc6d57625d
Deleted: sha256:f8491d2312b8e05d72537c3eb930e74221035da881ba3a1bc77d27921a747e3b
Deleted: sha256:b1e50fbb2bfe6049e368326caeca2dd16ca26b24d694dfb399479b037893a8b2
Deleted: sha256:877b896056aee0f148c22ffb6cf7c908c04a25dda678a89b93a0227b0d85f14d
Deleted: sha256:7ab3e314e49f4b98e06388492976cec09d2eb050500550419909ee15577f9685
Deleted: sha256:659324f7282dddd21dabb4e7e4f3777099f0f9470cb53944ced9fc1f67ec2107
Deleted: sha256:0ab33a708a4bb2f6e5b76842fdfc9a7aea96b1a738f812424d3a06c6a52756c0
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dcaa1b6ecfd0d2388b7e9c78ade199900e4c67320957ce0289d8df0a0f291196
  Associated tags:
 - 20230327-083147
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-083147].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dcaa1b6ecfd0d2388b7e9c78ade199900e4c67320957ce0289d8df0a0f291196].
$ rm -rf /tmp/tmp.NwaVjAti9A
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327082040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62166a5ac5c658108c1c942e45b5651055e479da967f0291f3dc41bde3df0dd8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327082040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8e15f98bc94418a023a1dc9ab9cb215537818c014a915315f5ab4ea8d47c1d81].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3444213.
Stopping expansion service pid: 3444214.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 15s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/662amksytojg4

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1451

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1451/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-023055",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327022041",
            "environmentId": "HfCWEdgHrPbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-023055"
      }
    ]
  },
  "name": "go-testxlang_partition-239",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/27 03:15:24 Submitted job: 2023-03-26_20_15_23-9791852426034797756
2023/03/27 03:15:24 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-26_20_15_23-9791852426034797756?project=apache-beam-testing
2023/03/27 03:15:24 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-26_20_15_23-9791852426034797756
2023/03/27 03:15:24 Job state: JOB_STATE_PENDING ...
2023/03/27 03:15:54 Job still running ...
2023/03/27 03:16:24 Job still running ...
2023/03/27 03:16:54 Job still running ...
2023/03/27 03:17:24 Job still running ...
2023/03/27 03:17:54 Job still running ...
2023/03/27 03:18:24 Job still running ...
2023/03/27 03:18:54 Job still running ...
2023/03/27 03:19:24 Job still running ...
2023/03/27 03:19:54 Job still running ...
2023/03/27 03:20:24 Job still running ...
2023/03/27 03:20:54 Job still running ...
2023/03/27 03:21:24 Job still running ...
2023/03/27 03:21:54 Job still running ...
2023/03/27 03:22:24 Job still running ...
2023/03/27 03:22:54 Job still running ...
2023/03/27 03:23:24 Job still running ...
2023/03/27 03:23:55 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-26_20_15_23-9791852426034797756 failed
--- FAIL: TestXLang_Partition (550.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3177.365s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679884291260968778
--- FAIL: TestBigQueryIO_BasicWriteRead (4.66s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41039 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@kuLOfkFjUP" is_bounded:BOUNDED windowing_strategy_id:"w0@kuLOfkFjUP"}} windowing_strategies:{key:"w0@kuLOfkFjUP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@kuLOfkFjUP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@kuLOfkFjUP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@kuLOfkFjUP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679884291260968778\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"kuLOfkFjUP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41039 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@kuLOfkFjUP" is_bounded:BOUNDED windowing_strategy_id:"w0@kuLOfkFjUP"}} windowing_strategies:{key:"w0@kuLOfkFjUP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@kuLOfkFjUP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@kuLOfkFjUP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@kuLOfkFjUP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679884291260968778\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"kuLOfkFjUP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000692d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000692d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040e600?, 0xc0001142d0?}, {0x113b23e, 0x39}, {0xc00015c0c0?, 0xa9ea20?, 0x1?}, {0xc000043070, 0xf}, 0xc0006abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040e5a0?, 0xc0001142d0?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc0006abea8, 0x2, 0x7f1f88985e68?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043070, 0xf}, {0xc00004c5a0, 0x52}, {0xebcb60, 0xc0004101b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000529380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000529380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.695s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f3f9ed2f19f0e01fdc819c811bec713bf595f9997509e2c585597c36d9a7c00
  Associated tags:
 - 20230327-023055
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-023055
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230327-023055].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f3f9ed2f19f0e01fdc819c811bec713bf595f9997509e2c585597c36d9a7c00].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:73ead4551adea8d007a46a3e75de667b9669b242150e9da95f4ebd16792c0bb6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230327022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:73ead4551adea8d007a46a3e75de667b9669b242150e9da95f4ebd16792c0bb6])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:73ead4551adea8d007a46a3e75de667b9669b242150e9da95f4ebd16792c0bb6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:73ead4551adea8d007a46a3e75de667b9669b242150e9da95f4ebd16792c0bb6].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a60487775c00fd6077539cedd2b5890286aef658986bfbefb14e220adbcb3875]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230327022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a60487775c00fd6077539cedd2b5890286aef658986bfbefb14e220adbcb3875])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a60487775c00fd6077539cedd2b5890286aef658986bfbefb14e220adbcb3875
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a60487775c00fd6077539cedd2b5890286aef658986bfbefb14e220adbcb3875].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 10s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1450

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1450/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326202041",
            "environmentId": "fNzxYhUmBLbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208"
      }
    ]
  },
  "name": "go-testxlang_partition-674",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/26 21:17:41 Submitted job: 2023-03-26_14_17_41-8320540947130749659
2023/03/26 21:17:41 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-26_14_17_41-8320540947130749659?project=apache-beam-testing
2023/03/26 21:17:41 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-26_14_17_41-8320540947130749659
2023/03/26 21:17:41 Job state: JOB_STATE_PENDING ...
2023/03/26 21:18:11 Job still running ...
2023/03/26 21:18:41 Job still running ...
2023/03/26 21:19:11 Job still running ...
2023/03/26 21:19:41 Job still running ...
2023/03/26 21:20:11 Job still running ...
2023/03/26 21:20:41 Job still running ...
2023/03/26 21:21:12 Job still running ...
2023/03/26 21:21:42 Job still running ...
2023/03/26 21:22:12 Job still running ...
2023/03/26 21:22:42 Job still running ...
2023/03/26 21:23:12 Job still running ...
2023/03/26 21:23:42 Job still running ...
2023/03/26 21:24:12 Job still running ...
2023/03/26 21:24:42 Job still running ...
2023/03/26 21:25:12 Job still running ...
2023/03/26 21:25:42 Job still running ...
2023/03/26 21:26:12 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-26_14_17_41-8320540947130749659 failed
--- FAIL: TestXLang_Partition (550.87s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3240.476s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679862765285034851
--- FAIL: TestBigQueryIO_BasicWriteRead (4.63s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36283 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dlwYSXibCg" is_bounded:BOUNDED windowing_strategy_id:"w0@dlwYSXibCg"}} windowing_strategies:{key:"w0@dlwYSXibCg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dlwYSXibCg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dlwYSXibCg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dlwYSXibCg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679862765285034851\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dlwYSXibCg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36283 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dlwYSXibCg" is_bounded:BOUNDED windowing_strategy_id:"w0@dlwYSXibCg"}} windowing_strategies:{key:"w0@dlwYSXibCg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dlwYSXibCg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dlwYSXibCg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dlwYSXibCg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679862765285034851\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dlwYSXibCg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000111640})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000111640})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004080a0?, 0xc00044e000?}, {0x113b23e, 0x39}, {0xc00045c000?, 0xa9ea20?, 0x1?}, {0xc0004ecba0, 0xf}, 0xc0000f3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000408020?, 0xc00044e000?}, {0xc0001167e0, 0x52}, {0x1?}, {0xc0000f3ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0004ecba0, 0xf}, {0xc0001167e0, 0x52}, {0xebcb60, 0xc00040c1a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001ac9c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001ac9c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.662s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:20af3015ae8edc81f04f172140593688ffb0c0708b8503455573d418652bb621
Deleted: sha256:e838197f65943bfd5a819ea39f34343a4dbf15459e51d43e3cad2f42a2402f24
Deleted: sha256:a8d12e3babc0901346884ba1af91f6ebedce07c9275d3817ddd22b232b9ea284
Deleted: sha256:c3a413b7af628390e8215561003f5301b849b804e7b25fb3ab3bd245a0c4340c
Deleted: sha256:f784840d9eb2571300c88db67032ad1f0505530579ad56b1661ac23d737caee2
Deleted: sha256:66cc901f40ed9e023a12dbf452bf57275a61e027b931cc94a97438dcac9c188f
Deleted: sha256:1720d9a158759c1b5d3993c090ace4609307edaae18c33bf65fe88260c11462c
Deleted: sha256:e0e765c8ebba4299b4fe1bbf32e64812e6a489a1bc171adefd7da388a00ac38e
Deleted: sha256:ba6bf49bf692d3af0a1baf37e61f58679d41eabc5d1f2f26edc5f808f4a7dc0d
Deleted: sha256:fbef254850e1e4237c923161f72da5303825b9c7e0a4d46cdf40cfac5b9803f0
Deleted: sha256:c44b9bcb3eca1c9f33fb5e09ebba1db620159962d83e37647d537ca5acd323f5
Deleted: sha256:6fdf9d72358352c3f85d15983e4ae695340a6e6e2936e5b90ff0368bcb1f5886
Deleted: sha256:5181394af3329980cc5db51451579b7f88b3d2b2efbac5560aa8d19f4a4216ad
Deleted: sha256:107b77dc28353526ea0d90bbc096ed69a0cd394f87d7f29a85f840f67dcdff6c
Deleted: sha256:79e0ea279b333d0cba0c22cc36369b5eb0d53fbed448a69ac6ab6d4220651ae9
Deleted: sha256:cf2f50642e8f29b7a364f1a678ce7c79f4bf72082ce6e5eef949d1640bffec34
Deleted: sha256:7957fb89a85b2f6900600730ae6021b08c1a187ad337f19bde23b830f11f8671
Deleted: sha256:f1e53ac08401ec18313d46212858d5cb549e856442c62dedbbe82801985e7ed8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:20af3015ae8edc81f04f172140593688ffb0c0708b8503455573d418652bb621
  Associated tags:
 - 20230326-203208
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-203208].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:20af3015ae8edc81f04f172140593688ffb0c0708b8503455573d418652bb621].
$ rm -rf /tmp/tmp.WWDJ2ekQrn
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e16c86adb209a018e2c45b78c127adbd76c188cd4e6525353240fb5b9d67d7dd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02
Deleted: sha256:86405df63cb9df582e2dc094ad07f9de368f3083f55b67c73674c512160827ac
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:32136e582a45f72d87903d78fd3d3e30a6518b306a2d473ec231d0bac413ee02].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2992755.
Stopping expansion service pid: 2992756.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 26s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1449

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1449/display/redirect>

Changes:


------------------------------------------
[...truncated 1019.64 KB...]
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805"
      }
    ]
  },
  "name": "go-testxlang_partition-633",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/26 15:13:11 Submitted job: 2023-03-26_08_13_10-12944461804618405893
2023/03/26 15:13:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-26_08_13_10-12944461804618405893?project=apache-beam-testing
2023/03/26 15:13:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-26_08_13_10-12944461804618405893
2023/03/26 15:13:11 Job state: JOB_STATE_PENDING ...
2023/03/26 15:13:41 Job still running ...
2023/03/26 15:14:11 Job still running ...
2023/03/26 15:14:41 Job still running ...
2023/03/26 15:15:11 Job still running ...
2023/03/26 15:15:41 Job still running ...
2023/03/26 15:16:11 Job still running ...
2023/03/26 15:16:41 Job still running ...
2023/03/26 15:17:11 Job still running ...
2023/03/26 15:17:41 Job still running ...
2023/03/26 15:18:11 Job still running ...
2023/03/26 15:18:41 Job still running ...
2023/03/26 15:19:11 Job still running ...
2023/03/26 15:19:41 Job still running ...
2023/03/26 15:20:11 Job still running ...
2023/03/26 15:20:41 Job still running ...
2023/03/26 15:21:11 Job still running ...
2023/03/26 15:21:41 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-26_08_13_10-12944461804618405893 failed
--- FAIL: TestXLang_Partition (552.64s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3213.424s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679840921744808931
--- FAIL: TestBigQueryIO_BasicWriteRead (4.47s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38755 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RfbheQZVPX" is_bounded:BOUNDED windowing_strategy_id:"w0@RfbheQZVPX"}} windowing_strategies:{key:"w0@RfbheQZVPX" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RfbheQZVPX" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RfbheQZVPX" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RfbheQZVPX" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679840921744808931\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RfbheQZVPX"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38755 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RfbheQZVPX" is_bounded:BOUNDED windowing_strategy_id:"w0@RfbheQZVPX"}} windowing_strategies:{key:"w0@RfbheQZVPX" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RfbheQZVPX" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RfbheQZVPX" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RfbheQZVPX" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679840921744808931\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RfbheQZVPX"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000026800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000026800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e13a0?, 0xc0001b19a0?}, {0x113b23e, 0x39}, {0xc0001d20c0?, 0xa9ea20?, 0x1?}, {0xc0001a9580, 0xf}, 0xc000177d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e1340?, 0xc0001b19a0?}, {0xc00013c3c0, 0x52}, {0x1?}, {0xc000177ea8, 0x2, 0x7f5e545e4b00?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001a9580, 0xf}, {0xc00013c3c0, 0x52}, {0xebcb60, 0xc00017a890})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102d00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.501s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68cb47136007fccca896a99cf8d321703fa42b250a85e6cf28c84499522be5e7
Deleted: sha256:480d7f4d0df32760ae539501a31a0d150224aa11f1575aea19397561b126634b
Deleted: sha256:d914497569b805f6cb1dd99b38e5850a5dd560632da5a6603efc5cc135c77b41
Deleted: sha256:60d0bf9b81e11b41eb23b63b38f912ad095409aacb954c9dbbf5bc4726c9219f
Deleted: sha256:f0f0161ab513256129672420af3116aad9e56d5d04af85413fc2adac889c9e15
Deleted: sha256:84e6c5c543714b95c0016a2abc186fef72969daa872bdd5b7e8e33e06b229ea6
Deleted: sha256:7cbdd42835039e712436b77428475c658467cd7e0dbf819cb00751b124b10ac7
Deleted: sha256:dcf84f07b4aa8ab23c9fdcf5aac2c3667c0d7cf486b8662dcec37b8ba3d35ae7
Deleted: sha256:e9051f5dd2f020b5f530a88b5bd00f436ff78e6e20cf88773533eefae3dd492d
Deleted: sha256:7de99f9eeb4973022ed21267d1cffe7058ed2e7b8e766b83c7b8403bafc4384d
Deleted: sha256:7d7224ebc297da54dd4651f16223a4ff4b0440e62f02c26a6877aa42572aa17d
Deleted: sha256:076b21cbea1643008f62ac25c98c7bd38ce5eaaddaf503c3dc5739035b3691b9
Deleted: sha256:f001a02c0c44d8479c4e441c679a8b6a0c8f47f2b42053e0f6e9849a5f8856e1
Deleted: sha256:902d241133ec1d00772619282a15a12d0d76055b05b2c92063d9b30103e0b515
Deleted: sha256:a8531f1f7dc5825245e03665cee772531549ce7a3cc7131aa7cbcd7cb9a63654
Deleted: sha256:ff66dd737c531fb062e022017316c9502cca6b270c4933b5007ef85ea932a619
Deleted: sha256:102769e54809e364bfb8e57f3fec065e81838c913188f628d49a8571027d344a
Deleted: sha256:2eca8879bb18e2aaa112997fee8855d75ae35acf0ba0b795cfe1246059069fa8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68cb47136007fccca896a99cf8d321703fa42b250a85e6cf28c84499522be5e7
  Associated tags:
 - 20230326-142805
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-142805].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68cb47136007fccca896a99cf8d321703fa42b250a85e6cf28c84499522be5e7].
$ rm -rf /tmp/tmp.NU2BW6GR2r
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326142033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326142033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326142033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae4fb1d250093395e41da1b546dcdfa0d083e7b0ddd745bbb1214b8a7dcaddc].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326142033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699
Deleted: sha256:88344237cd99448b0b67daef94f53cd70161c3b6c63060871cd129b1bfcdaead
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326142033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326142033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eceaf1d695bd335722a0e6a44e5fb4eec1b68df65919ddcc5553f6526bd26699].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2876769.
Stopping expansion service pid: 2876770.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 2m 10s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1448

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1448/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-083048",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326082028",
            "environmentId": "egnXcvczQSbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-083048"
      }
    ]
  },
  "name": "go-testxlang_partition-299",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/26 09:15:52 Submitted job: 2023-03-26_02_15_51-13166386328982084408
2023/03/26 09:15:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-26_02_15_51-13166386328982084408?project=apache-beam-testing
2023/03/26 09:15:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-26_02_15_51-13166386328982084408
2023/03/26 09:15:52 Job state: JOB_STATE_PENDING ...
2023/03/26 09:16:22 Job still running ...
2023/03/26 09:16:52 Job still running ...
2023/03/26 09:17:22 Job still running ...
2023/03/26 09:17:52 Job still running ...
2023/03/26 09:18:22 Job still running ...
2023/03/26 09:18:52 Job still running ...
2023/03/26 09:19:22 Job still running ...
2023/03/26 09:19:52 Job still running ...
2023/03/26 09:20:22 Job still running ...
2023/03/26 09:20:52 Job still running ...
2023/03/26 09:21:23 Job still running ...
2023/03/26 09:21:53 Job still running ...
2023/03/26 09:22:23 Job still running ...
2023/03/26 09:22:53 Job still running ...
2023/03/26 09:23:23 Job still running ...
2023/03/26 09:23:53 Job still running ...
2023/03/26 09:24:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-26_02_15_51-13166386328982084408 failed
--- FAIL: TestXLang_Partition (551.07s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.846s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679819485754526762
--- FAIL: TestBigQueryIO_BasicWriteRead (5.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38447 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@obZQewOpAT" is_bounded:BOUNDED windowing_strategy_id:"w0@obZQewOpAT"}} windowing_strategies:{key:"w0@obZQewOpAT" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@obZQewOpAT" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@obZQewOpAT" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@obZQewOpAT" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679819485754526762\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"obZQewOpAT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38447 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@obZQewOpAT" is_bounded:BOUNDED windowing_strategy_id:"w0@obZQewOpAT"}} windowing_strategies:{key:"w0@obZQewOpAT" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@obZQewOpAT" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@obZQewOpAT" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@obZQewOpAT" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679819485754526762\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"obZQewOpAT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 54 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000510940})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000510940})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169aa0?, 0xc0000e1680?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9ea20?, 0x1?}, {0xc00050ed90, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169a40?, 0xc0000e1680?}, {0xc00004c540, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f1efda2a180?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00050ed90, 0xf}, {0xc00004c540, 0x52}, {0xebcb60, 0xc00057e0a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0002ff380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0002ff380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.588s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.075s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.060s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e522f0a698d79bc6595b49d734dc38232866f1430f68b7182462f677e8f89a52
  Associated tags:
 - 20230326-083048
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-083048
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-083048].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e522f0a698d79bc6595b49d734dc38232866f1430f68b7182462f677e8f89a52].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1669ce797e734673d44aa739405ae19fd07ebddbb66c80fabcf64ac80255de60]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1669ce797e734673d44aa739405ae19fd07ebddbb66c80fabcf64ac80255de60])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1669ce797e734673d44aa739405ae19fd07ebddbb66c80fabcf64ac80255de60
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1669ce797e734673d44aa739405ae19fd07ebddbb66c80fabcf64ac80255de60].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0307e73a572fb95b41bd821149d0b038788fbdc6e4c388261cc7b46235425627]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0307e73a572fb95b41bd821149d0b038788fbdc6e4c388261cc7b46235425627])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0307e73a572fb95b41bd821149d0b038788fbdc6e4c388261cc7b46235425627
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0307e73a572fb95b41bd821149d0b038788fbdc6e4c388261cc7b46235425627].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 50s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1447

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1447/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326022041",
            "environmentId": "aiNiUIwybbbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126"
      }
    ]
  },
  "name": "go-testxlang_partition-673",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/26 03:15:59 Submitted job: 2023-03-25_20_15_58-11305940046267834889
2023/03/26 03:15:59 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-25_20_15_58-11305940046267834889?project=apache-beam-testing
2023/03/26 03:15:59 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-25_20_15_58-11305940046267834889
2023/03/26 03:15:59 Job state: JOB_STATE_PENDING ...
2023/03/26 03:16:29 Job still running ...
2023/03/26 03:16:59 Job still running ...
2023/03/26 03:17:29 Job still running ...
2023/03/26 03:17:59 Job still running ...
2023/03/26 03:18:29 Job still running ...
2023/03/26 03:18:59 Job still running ...
2023/03/26 03:19:29 Job still running ...
2023/03/26 03:19:59 Job still running ...
2023/03/26 03:20:29 Job still running ...
2023/03/26 03:20:59 Job still running ...
2023/03/26 03:21:30 Job still running ...
2023/03/26 03:22:00 Job still running ...
2023/03/26 03:22:30 Job still running ...
2023/03/26 03:23:00 Job still running ...
2023/03/26 03:23:30 Job still running ...
2023/03/26 03:24:00 Job still running ...
2023/03/26 03:24:30 Job still running ...
2023/03/26 03:25:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-25_20_15_58-11305940046267834889 failed
--- FAIL: TestXLang_Partition (580.54s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3209.902s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679797923711558411
--- FAIL: TestBigQueryIO_BasicWriteRead (4.61s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36259 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YMaSnqCxZu" is_bounded:BOUNDED windowing_strategy_id:"w0@YMaSnqCxZu"}} windowing_strategies:{key:"w0@YMaSnqCxZu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YMaSnqCxZu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YMaSnqCxZu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YMaSnqCxZu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679797923711558411\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YMaSnqCxZu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36259 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YMaSnqCxZu" is_bounded:BOUNDED windowing_strategy_id:"w0@YMaSnqCxZu"}} windowing_strategies:{key:"w0@YMaSnqCxZu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YMaSnqCxZu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YMaSnqCxZu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YMaSnqCxZu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679797923711558411\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YMaSnqCxZu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0005a8940})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0005a8940})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003e2ca0?, 0xc0000bd9f0?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000122fe0, 0xf}, 0xc000167d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003e2c40?, 0xc0000bd9f0?}, {0xc0004b03c0, 0x52}, {0x1?}, {0xc000167ea8, 0x2, 0x7fec9c0b4c30?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122fe0, 0xf}, {0xc0004b03c0, 0x52}, {0xebcb60, 0xc0000ea320})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003e0820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003e0820, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.639s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ce20d87052224d56c1719cbbbf7013caa744a1118ae818b1cabea2cf36ac4cb6
Deleted: sha256:39bfca4fd7933e6bac6e389daf81d65c7ad7c3a15ca8d7248a01b1e848b4b322
Deleted: sha256:61d6a2986cdba1f698e6594d51ffd4abfb16e65e813c5547b6bf39f249a7f88b
Deleted: sha256:ba667552bd15822d4e379bd153b1745d2ee855e9b3176676027624c77743aa18
Deleted: sha256:2b953e60516b319916ca11ce545d97908ee83f0895590b90e9f4c5f52e0fb6ad
Deleted: sha256:e3b9360aa7d2810af9dd351d58c387f38f0d4a76ebcf7deae10746ecfe8ef290
Deleted: sha256:aac672279ccc29f2254b8aaf592d1a695977b522ec7308510fe88904314cd03b
Deleted: sha256:0323fd9fd69f46058388461c8170f2703d7ffc899159e1d7e45ef1c835e6f937
Deleted: sha256:abd1fe4900f77cc4b916cdeeebab950450d5d46a7e573cb4968b963e7af279e4
Deleted: sha256:f97cf564806ffd683ab6d4de0743e834a9263555491c8e4df73aa021d1366230
Deleted: sha256:ef131c9d2afd6be4892eeedaaffa36ffbca886a9d7f7b69fdb0d4939e22ab07b
Deleted: sha256:6f524ec254e10f704fae0cdab1c50de4848ee201f361c568b3db656cf4192285
Deleted: sha256:d7c8c509e6a812e9d0ca1285783d2317d3683cf237b1aa00a13e998bc4b2ed20
Deleted: sha256:960a018042a86066aa8b29fd11c9769277adfc18a3dde9ebeda55b772e1c3f8d
Deleted: sha256:456098b295866da7df72127e720f921adf5a86a7318705f29a1ddbc683d91a8c
Deleted: sha256:49a8110654dbb59bc449cc070298f21e4928ecf06487ff5fe707c1bd9f226c50
Deleted: sha256:a114d71ea9c598cbedca7da753802691e63ddfe8d54e4fba0a26692f2d2aa9ae
Deleted: sha256:3863c75be7034682896de2b78c7b2d293d0ddf4c96aeab15d25cb5bbb2610b19
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ce20d87052224d56c1719cbbbf7013caa744a1118ae818b1cabea2cf36ac4cb6
  Associated tags:
 - 20230326-023126
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230326-023126].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ce20d87052224d56c1719cbbbf7013caa744a1118ae818b1cabea2cf36ac4cb6].
$ rm -rf /tmp/tmp.HHY9tnAJ14
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230326022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3eef4ebc127cd5ed1cac6631ef968d7e81e767935a8d4b809bba08cbade92e0f].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230326022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab1f6654b3e71cc0f255b1e43369a2ce5109e7b12e895c551fb21f031a5390f4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2569065.
Stopping expansion service pid: 2569066.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 17s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1446

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1446/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325202040",
            "environmentId": "tTVWBHyvfgbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-203104",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-203104"
      }
    ]
  },
  "name": "go-testxlang_partition-421",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/25 21:17:12 Submitted job: 2023-03-25_14_17_12-14634858388016616754
2023/03/25 21:17:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-25_14_17_12-14634858388016616754?project=apache-beam-testing
2023/03/25 21:17:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-25_14_17_12-14634858388016616754
2023/03/25 21:17:12 Job state: JOB_STATE_PENDING ...
2023/03/25 21:17:42 Job still running ...
2023/03/25 21:18:12 Job still running ...
2023/03/25 21:18:42 Job still running ...
2023/03/25 21:19:12 Job still running ...
2023/03/25 21:19:42 Job still running ...
2023/03/25 21:20:13 Job still running ...
2023/03/25 21:20:43 Job still running ...
2023/03/25 21:21:13 Job still running ...
2023/03/25 21:21:43 Job still running ...
2023/03/25 21:22:13 Job still running ...
2023/03/25 21:22:43 Job still running ...
2023/03/25 21:23:13 Job still running ...
2023/03/25 21:23:43 Job still running ...
2023/03/25 21:24:13 Job still running ...
2023/03/25 21:24:43 Job still running ...
2023/03/25 21:25:13 Job still running ...
2023/03/25 21:25:43 Job still running ...
2023/03/25 21:26:13 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-25_14_17_12-14634858388016616754 failed
--- FAIL: TestXLang_Partition (581.06s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3307.168s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679776299895443852
--- FAIL: TestBigQueryIO_BasicWriteRead (4.58s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40079 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@OAwRQTlZVz" is_bounded:BOUNDED windowing_strategy_id:"w0@OAwRQTlZVz"}} windowing_strategies:{key:"w0@OAwRQTlZVz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@OAwRQTlZVz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@OAwRQTlZVz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@OAwRQTlZVz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679776299895443852\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"OAwRQTlZVz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40079 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@OAwRQTlZVz" is_bounded:BOUNDED windowing_strategy_id:"w0@OAwRQTlZVz"}} windowing_strategies:{key:"w0@OAwRQTlZVz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@OAwRQTlZVz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@OAwRQTlZVz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@OAwRQTlZVz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679776299895443852\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"OAwRQTlZVz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000152c40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000152c40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00058eaa0?, 0xc0001399a0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc0000430f0, 0xf}, 0xc0005c3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00058ea40?, 0xc0001399a0?}, {0xc00010e900, 0x52}, {0x1?}, {0xc0005c3ea8, 0x2, 0x7f73326663e8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0000430f0, 0xf}, {0xc00010e900, 0x52}, {0xebcb60, 0xc0005d0400})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001bb380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001bb380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.615s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:26f6c962818421dfa1debc2cee2b2d327709753c1558aa506a318121536b4d78
  Associated tags:
 - 20230325-203104
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-203104
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-203104].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:26f6c962818421dfa1debc2cee2b2d327709753c1558aa506a318121536b4d78].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3e23b4b26a0a1cba96d810f4d4da739bfe8b725520255162349ded24e369765c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3e23b4b26a0a1cba96d810f4d4da739bfe8b725520255162349ded24e369765c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3e23b4b26a0a1cba96d810f4d4da739bfe8b725520255162349ded24e369765c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3e23b4b26a0a1cba96d810f4d4da739bfe8b725520255162349ded24e369765c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5b5d54cfebc938c2e879235ff8a4149beb499cc1dba0be2ec64128b15f79916]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5b5d54cfebc938c2e879235ff8a4149beb499cc1dba0be2ec64128b15f79916])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5b5d54cfebc938c2e879235ff8a4149beb499cc1dba0be2ec64128b15f79916
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5b5d54cfebc938c2e879235ff8a4149beb499cc1dba0be2ec64128b15f79916].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 29s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1445

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1445/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325142033",
            "environmentId": "sBFIxKQbRIbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128"
      }
    ]
  },
  "name": "go-testxlang_partition-917",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/25 15:18:07 Submitted job: 2023-03-25_08_18_07-15161098600335186679
2023/03/25 15:18:07 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-25_08_18_07-15161098600335186679?project=apache-beam-testing
2023/03/25 15:18:07 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-25_08_18_07-15161098600335186679
2023/03/25 15:18:07 Job state: JOB_STATE_PENDING ...
2023/03/25 15:18:37 Job still running ...
2023/03/25 15:19:07 Job still running ...
2023/03/25 15:19:37 Job still running ...
2023/03/25 15:20:07 Job still running ...
2023/03/25 15:20:37 Job still running ...
2023/03/25 15:21:07 Job still running ...
2023/03/25 15:21:37 Job still running ...
2023/03/25 15:22:07 Job still running ...
2023/03/25 15:22:38 Job still running ...
2023/03/25 15:23:08 Job still running ...
2023/03/25 15:23:38 Job still running ...
2023/03/25 15:24:08 Job still running ...
2023/03/25 15:24:38 Job still running ...
2023/03/25 15:25:08 Job still running ...
2023/03/25 15:25:38 Job still running ...
2023/03/25 15:26:08 Job still running ...
2023/03/25 15:26:38 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-25_08_18_07-15161098600335186679 failed
--- FAIL: TestXLang_Partition (550.99s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3300.993s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679754730685953393
--- FAIL: TestBigQueryIO_BasicWriteRead (5.70s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46751 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@gzagwcXyvV" is_bounded:BOUNDED windowing_strategy_id:"w0@gzagwcXyvV"}} windowing_strategies:{key:"w0@gzagwcXyvV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@gzagwcXyvV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@gzagwcXyvV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@gzagwcXyvV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679754730685953393\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"gzagwcXyvV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46751 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@gzagwcXyvV" is_bounded:BOUNDED windowing_strategy_id:"w0@gzagwcXyvV"}} windowing_strategies:{key:"w0@gzagwcXyvV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@gzagwcXyvV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@gzagwcXyvV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@gzagwcXyvV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679754730685953393\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"gzagwcXyvV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000018700})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000018700})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a70e0?, 0xc0001819f0?}, {0x113b23e, 0x39}, {0xc0001d20c0?, 0xa9ea20?, 0x1?}, {0xc0001ab6a0, 0xf}, 0xc00016dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7080?, 0xc0001819f0?}, {0xc000182840, 0x52}, {0x1?}, {0xc00016dea8, 0x2, 0x7f5e6e876d20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001ab6a0, 0xf}, {0xc000182840, 0x52}, {0xebcb60, 0xc0001729b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103a00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.741s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.041s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b66ebdc5e3e9d9915db6d24dd9fa6843d6131febd01df64e0be3adfc40cca9fe
Deleted: sha256:2b7a3d71cc7bd858c1fdadfd66a7a35a38f9fcd2786308f1ecf27853d4d32e5c
Deleted: sha256:0ac4c1ea322a2900112c79d79c3ae6eb4294de15f44ee834caf6b9d75f514911
Deleted: sha256:ab86dc857912ba80fd31af8418413aea087aa53372e7ae67aea39c83b4de39ee
Deleted: sha256:f40d9a704bfcd00684377d64dc4bb6fa7a17075c4ed05aba2cb816a05dae0046
Deleted: sha256:4a119e956d5b5d17f9e8eee7a1307dce5f823cf7f58213ea713692639b909680
Deleted: sha256:b7f5120b0d355e510c32fd91b18cb2c99ccd6e052582d799a53e54dcf05723bb
Deleted: sha256:e64b0a1dbe6c21f49adba550a2c037b6e1527d0e44d42cdc341c30d3b720efce
Deleted: sha256:4b9a611a26532f7d51b66cbac30981f77156f26c4b24595caa4e34aa9ec237b5
Deleted: sha256:51e4a4a2a269d3b5359723fce54ed2645a028f7027c3021bcca80da4724da2ed
Deleted: sha256:32000e746e82d6de4d006f53693e27a1b060d0f467404760390f504c3a528c55
Deleted: sha256:3656ae55aa698773d8639cd710b067216a3899b990a432886b8fc048ff721970
Deleted: sha256:a28d8956a898389ab81face47893b5ad296e39cae633262de6cef13afe894bde
Deleted: sha256:105e6250a11c556141cb56a746e791d491f247c3b401e74f7be7f281b4b52ebe
Deleted: sha256:d97fcedc839fad57d92c3ddaa74192f7a91fc2be703556bdd03b68eaeeb228f7
Deleted: sha256:a5b0d1abf599c7148a2af6b0359fcd9d049c2ef4d9c1a2f6ed2779d93b1da0cf
Deleted: sha256:782106710815816386b82a6ac12629db476b76a4b0e0a2372e9055ed10c37f3f
Deleted: sha256:d2eaa8520a48230b9af8eebc21429433f3d8628d4efe3fe7089bb58f857f73af
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b66ebdc5e3e9d9915db6d24dd9fa6843d6131febd01df64e0be3adfc40cca9fe
  Associated tags:
 - 20230325-143128
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-143128].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b66ebdc5e3e9d9915db6d24dd9fa6843d6131febd01df64e0be3adfc40cca9fe].
$ rm -rf /tmp/tmp.y3aorOkvbX
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325142033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325142033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325142033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c675822646ff34f6b6573495fcc2a4e509a715dc1def419889b23ca9af821cbe].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325142033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325142033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325142033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:527ec9150bf79cfa37a20a0f23193ba02da72695197ff4efcea87358d0610776].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2148804.
Stopping expansion service pid: 2148805.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 2s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1444

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1444/display/redirect?page=changes>

Changes:

[noreply] Merge pull request #25868: Fix :examples:java:execute so it can be used


------------------------------------------
[...truncated 693.50 KB...]
#14 211.7 WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
#14 DONE 212.7s

#15 [beam 11/16] RUN pip check || (echo "Container does not include required Beam dependencies or has conflicting dependencies. If Beam dependencies have changed, you need to regenerate base_image_requirements.txt files. See: https://s.apache.org/beam-python-requirements-generate" && exit 1)
#15 2.064 No broken requirements found.
#15 DONE 2.2s

#16 [beam 12/16] RUN pip freeze --all
#16 1.011 absl-py==1.4.0
#16 1.011 apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
#16 1.011 astunparse==1.6.3
#16 1.011 attrs==22.2.0
#16 1.011 beautifulsoup4==4.11.2
#16 1.011 bs4==0.0.1
#16 1.011 cachetools==4.2.4
#16 1.011 certifi==2022.12.7
#16 1.011 cffi==1.15.1
#16 1.011 charset-normalizer==3.1.0
#16 1.011 click==8.1.3
#16 1.011 cloudpickle==2.2.1
#16 1.011 crcmod==1.7
#16 1.011 cryptography==39.0.2
#16 1.011 Cython==0.29.33
#16 1.011 deprecation==2.1.0
#16 1.011 dill==0.3.1.1
#16 1.011 dnspython==2.3.0
#16 1.011 docker==6.0.1
#16 1.011 docopt==0.6.2
#16 1.011 exceptiongroup==1.1.0
#16 1.011 execnet==1.9.0
#16 1.011 fastavro==1.7.3
#16 1.011 fasteners==0.18
#16 1.011 flatbuffers==23.3.3
#16 1.011 freezegun==1.2.2
#16 1.011 future==0.18.3
#16 1.011 gast==0.4.0
#16 1.011 google-api-core==2.11.0
#16 1.011 google-apitools==0.5.31
#16 1.011 google-auth==2.16.2
#16 1.011 google-auth-httplib2==0.1.0
#16 1.011 google-auth-oauthlib==0.4.6
#16 1.011 google-cloud-bigquery==3.6.0
#16 1.011 google-cloud-bigquery-storage==2.19.0
#16 1.011 google-cloud-bigtable==2.17.0
#16 1.011 google-cloud-core==2.3.2
#16 1.011 google-cloud-datastore==2.15.0
#16 1.011 google-cloud-dlp==3.12.0
#16 1.011 google-cloud-language==2.9.0
#16 1.011 google-cloud-pubsub==2.15.0
#16 1.011 google-cloud-pubsublite==1.7.0
#16 1.011 google-cloud-recommendations-ai==0.10.2
#16 1.011 google-cloud-spanner==3.28.0
#16 1.011 google-cloud-videointelligence==2.11.0
#16 1.011 google-cloud-vision==3.4.0
#16 1.011 google-crc32c==1.5.0
#16 1.011 google-pasta==0.2.0
#16 1.011 google-resumable-media==2.4.1
#16 1.011 googleapis-common-protos==1.58.0
#16 1.011 greenlet==2.0.2
#16 1.011 grpc-google-iam-v1==0.12.6
#16 1.011 grpcio==1.51.3
#16 1.011 grpcio-status==1.51.3
#16 1.011 guppy3==3.1.2
#16 1.011 h5py==3.8.0
#16 1.011 hdfs==2.7.0
#16 1.011 httplib2==0.21.0
#16 1.011 hypothesis==6.68.2
#16 1.011 idna==3.4
#16 1.011 importlib-metadata==6.0.0
#16 1.011 iniconfig==2.0.0
#16 1.011 jax==0.4.6
#16 1.011 joblib==1.2.0
#16 1.011 keras==2.12.0rc1
#16 1.011 libclang==15.0.6.1
#16 1.011 Markdown==3.4.1
#16 1.011 MarkupSafe==2.1.2
#16 1.011 mmh3==3.0.0
#16 1.011 mock==5.0.1
#16 1.011 nltk==3.8.1
#16 1.011 nose==1.3.7
#16 1.011 numpy==1.23.5
#16 1.011 oauth2client==4.1.3
#16 1.011 oauthlib==3.2.2
#16 1.011 objsize==0.6.1
#16 1.011 opt-einsum==3.3.0
#16 1.011 orjson==3.8.7
#16 1.011 overrides==6.5.0
#16 1.011 packaging==23.0
#16 1.011 pandas==1.5.3
#16 1.011 parameterized==0.8.1
#16 1.011 pip==23.0.1
#16 1.011 pluggy==1.0.0
#16 1.011 proto-plus==1.22.2
#16 1.011 protobuf==4.22.1
#16 1.011 psycopg2-binary==2.9.5
#16 1.011 py==1.11.0
#16 1.011 pyarrow==9.0.0
#16 1.011 pyasn1==0.4.8
#16 1.011 pyasn1-modules==0.2.8
#16 1.011 pycparser==2.21
#16 1.011 pydot==1.4.2
#16 1.011 PyHamcrest==1.10.1
#16 1.011 pymongo==4.3.3
#16 1.011 PyMySQL==1.0.2
#16 1.011 pyparsing==3.0.9
#16 1.011 pytest==7.2.2
#16 1.011 pytest-forked==1.6.0
#16 1.011 pytest-timeout==2.1.0
#16 1.011 pytest-xdist==2.5.0
#16 1.011 python-dateutil==2.8.2
#16 1.011 python-snappy==0.6.1
#16 1.011 pytz==2022.7.1
#16 1.011 PyYAML==6.0
#16 1.011 regex==2022.10.31
#16 1.011 requests==2.28.2
#16 1.011 requests-mock==1.10.0
#16 1.011 requests-oauthlib==1.3.1
#16 1.011 rsa==4.9
#16 1.011 scikit-learn==1.2.2
#16 1.011 scipy==1.10.1
#16 1.011 setuptools==67.6.0
#16 1.011 six==1.16.0
#16 1.011 sortedcontainers==2.4.0
#16 1.011 soupsieve==2.4
#16 1.011 SQLAlchemy==1.4.46
#16 1.011 sqlparse==0.4.3
#16 1.011 tenacity==5.1.5
#16 1.011 tensorboard==2.12.0
#16 1.011 tensorboard-data-server==0.7.0
#16 1.011 tensorboard-plugin-wit==1.8.1
#16 1.011 tensorflow==2.12.0rc1
#16 1.011 tensorflow-estimator==2.12.0rc0
#16 1.011 tensorflow-io-gcs-filesystem==0.31.0
#16 1.011 termcolor==2.2.0
#16 1.011 testcontainers==3.7.1
#16 1.011 threadpoolctl==3.1.0
#16 1.011 tomli==2.0.1
#16 1.011 tqdm==4.65.0
#16 1.011 typing_extensions==4.5.0
#16 1.011 urllib3==1.26.14
#16 1.011 websocket-client==1.5.1
#16 1.011 Werkzeug==2.2.3
#16 1.011 wheel==0.40.0
#16 1.011 wrapt==1.14.1
#16 1.011 zipp==3.15.0
#16 1.011 zstandard==0.20.0
#16 DONE 1.1s

#17 [beam 13/16] COPY target/LICENSE /opt/apache/beam/
#17 DONE 0.0s

#18 [beam 14/16] COPY target/LICENSE.python /opt/apache/beam/
#18 DONE 0.0s

#19 [beam 15/16] COPY target/NOTICE /opt/apache/beam/
#19 DONE 0.0s

#20 [beam 16/16] COPY target/launcher/linux_amd64/boot /opt/apache/beam/
#20 DONE 0.2s

#21 [third_party_licenses 1/5] COPY target/license_scripts /tmp/license_scripts/
#21 DONE 0.1s

#22 [third_party_licenses 2/5] COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
#22 DONE 0.1s

#23 [third_party_licenses 3/5] RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
#23 DONE 0.3s

#24 [third_party_licenses 4/5] COPY target/license_scripts /tmp/license_scripts/
#24 DONE 0.0s

#25 [third_party_licenses 5/5] RUN if [ "true" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
#25 1.055 Collecting pip-licenses<4.0.0
#25 1.129   Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
#25 1.137 Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
#25 1.138 Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
#25 1.176 Collecting PTable
#25 1.196   Downloading PTable-0.9.2.tar.gz (31 kB)
#25 1.213   Preparing metadata (setup.py): started
#25 1.565   Preparing metadata (setup.py): finished with status 'done'
#25 1.580 Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
#25 1.584 Building wheels for collected packages: PTable
#25 1.585   Building wheel for PTable (setup.py): started
#25 2.134   Building wheel for PTable (setup.py): finished with status 'done'
#25 2.135   Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=fae85ca7877aeb565cadeb825c4b1426ac0c848321a6e723c2da53024e154e02
#25 2.135   Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
#25 2.141 Successfully built PTable
#25 3.240 Installing collected packages: PTable, pip-licenses
#25 3.328 Successfully installed PTable-0.9.2 pip-licenses-3.5.5
#25 3.329 WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
#25 16.30 Skip pulling license for  bs4
#25 16.30 INFO:root:Successfully pulled licenses for 134 dependencies
#25 DONE 16.4s

#26 [stage-2 1/2] COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
#26 DONE 0.1s

#27 [stage-2 2/2] RUN if [ "true" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
#27 DONE 0.4s

#28 exporting to image
#28 exporting layers
#28 exporting layers 14.0s done
#28 writing image sha256:2dec1e9703537568ea1ef559beab60412b1d05e66e49140749b64061f2959690 done
#28 naming to docker.io/apache/beam_python3.8_sdk:2.47.0.dev done
#28 DONE 14.0s

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 11m 19s
223 actionable tasks: 147 executed, 64 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1443

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1443/display/redirect>

Changes:


------------------------------------------
[...truncated 1.05 MB...]
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325022540",
            "environmentId": "nfSxyHlYypbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737"
      }
    ]
  },
  "name": "go-testxlang_partition-892",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/25 03:23:22 Submitted job: 2023-03-24_20_23_21-14694045234912111206
2023/03/25 03:23:22 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-24_20_23_21-14694045234912111206?project=apache-beam-testing
2023/03/25 03:23:22 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-24_20_23_21-14694045234912111206
2023/03/25 03:23:22 Job state: JOB_STATE_PENDING ...
2023/03/25 03:23:52 Job still running ...
2023/03/25 03:24:22 Job still running ...
2023/03/25 03:24:52 Job still running ...
2023/03/25 03:25:22 Job still running ...
2023/03/25 03:25:52 Job still running ...
2023/03/25 03:26:22 Job still running ...
2023/03/25 03:26:52 Job still running ...
2023/03/25 03:27:22 Job still running ...
2023/03/25 03:27:52 Job still running ...
2023/03/25 03:28:22 Job still running ...
2023/03/25 03:28:52 Job still running ...
2023/03/25 03:29:22 Job still running ...
2023/03/25 03:29:52 Job still running ...
2023/03/25 03:30:23 Job still running ...
2023/03/25 03:30:53 Job still running ...
2023/03/25 03:31:23 Job still running ...
2023/03/25 03:31:53 Job still running ...
2023/03/25 03:32:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-24_20_23_21-14694045234912111206 failed
--- FAIL: TestXLang_Partition (582.30s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3277.498s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679711904252226050
--- FAIL: TestBigQueryIO_BasicWriteRead (5.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33431 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@CjWtQMDZjC" is_bounded:BOUNDED windowing_strategy_id:"w0@CjWtQMDZjC"}} windowing_strategies:{key:"w0@CjWtQMDZjC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@CjWtQMDZjC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@CjWtQMDZjC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@CjWtQMDZjC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679711904252226050\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"CjWtQMDZjC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33431 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@CjWtQMDZjC" is_bounded:BOUNDED windowing_strategy_id:"w0@CjWtQMDZjC"}} windowing_strategies:{key:"w0@CjWtQMDZjC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@CjWtQMDZjC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@CjWtQMDZjC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@CjWtQMDZjC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679711904252226050\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"CjWtQMDZjC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 55 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0002170c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0002170c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a74a0?, 0xc0006c1680?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000043670, 0xf}, 0xc00017dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7440?, 0xc0006c1680?}, {0xc00004c9c0, 0x52}, {0x1?}, {0xc00017dea8, 0x2, 0x7f3447b5a248?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043670, 0xf}, {0xc00004c9c0, 0x52}, {0xebcb60, 0xc0000e6980})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103ba0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.870s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.061s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:93b8b2e68d62777e8c9e1321a1a6f1364658b921e893b86e44ee8c541403de48
Deleted: sha256:27bb8a88183b670b3de3510e1898323948c89f5642920de7daa297dfb444d349
Deleted: sha256:6ded8e7cdc87a75debb5bdfdf041e419af77165d0547f28d4bb0f6ff0a2ae3ed
Deleted: sha256:a7d94aca8385533c4980c1c83095b8451630a1fe8d5e05c40d8dec6f20e21dea
Deleted: sha256:0f4a6dd71f5298d678ee67f94f74dac0f8fa46cc1391f59abcc87e9708d57940
Deleted: sha256:e41a0fbdb0aec4723a8d84eb0ed9d5e1cc93a44047f9d110065ae4d337391f31
Deleted: sha256:eb3e7bb1988270a588b137806a268138928494bca2019d0f2ba25a6fbfce3a93
Deleted: sha256:879567317aaea74c8af4a7c2d4e8b1f6c8898c299e1b3c9252bf83c72096e29b
Deleted: sha256:e46148f9d47deb3c17d9bdf012452afff3e18e1d041d77693ddd0f419fd75813
Deleted: sha256:d7ed30af9ce71bbe3925073027ffdd28ac2963b4ae93eb809cb4734dc443db2c
Deleted: sha256:d004add3633e639bfe921706bf78cc2d0caa744e62a9fdff918efabc469cd493
Deleted: sha256:7b91ecb6e870650b6a1d539e02dab023d22c31c21843ba060266cdd6917f20cb
Deleted: sha256:e9b5284a02acbeff6e3bb9d8de024b8fcbd2ddb18e574da38171178d7277ae6b
Deleted: sha256:03b21ce0f446121906f05feebaf0f24a40ba93f7c9d1c5dc79895351ae6c0346
Deleted: sha256:c769d367a2ba937c243c36c1b64cd66c72ec1e7213d8797a6f76345adb21980d
Deleted: sha256:ac3e34e98448f11ac2008efea3da0f6f331719bdf5522425f99df15c78c945da
Deleted: sha256:f6a5bc68a73821d935d07a57fe1d8b5603b6c2d30e9fd709ab347fa24c576e01
Deleted: sha256:7a077cea8b6d50350ca79d2dfe660c5c24c62f6b46ff4ff23cde69de5a54e4a0
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:93b8b2e68d62777e8c9e1321a1a6f1364658b921e893b86e44ee8c541403de48
  Associated tags:
 - 20230325-023737
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230325-023737].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:93b8b2e68d62777e8c9e1321a1a6f1364658b921e893b86e44ee8c541403de48].
$ rm -rf /tmp/tmp.MnRSnuQjq9
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325022540
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663
Deleted: sha256:12b5cd373c676713f6a0c47d26487fe66e0520296066438f80df5cd196ca6bec
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325022540]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230325022540] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:11d39cc7b46fe763cfb974a6953786e42bf6236ccf5d57135d1e3e0417f50663].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325022540
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325022540]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230325022540] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43c3215e609973e5513401e69c613fdd93015f2635cf1056c51d0bd17cef2dc1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3534501.
Stopping expansion service pid: 3534502.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 54s
232 actionable tasks: 178 executed, 44 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1442

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1442/display/redirect?page=changes>

Changes:

[noreply] Merge pull request #25916 Use built-in csv and json readers.


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147"
      }
    ]
  },
  "name": "go-testxlang_partition-50",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/24 21:17:51 Submitted job: 2023-03-24_14_17_50-5829823784135220699
2023/03/24 21:17:51 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-24_14_17_50-5829823784135220699?project=apache-beam-testing
2023/03/24 21:17:51 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-24_14_17_50-5829823784135220699
2023/03/24 21:17:51 Job state: JOB_STATE_PENDING ...
2023/03/24 21:18:21 Job still running ...
2023/03/24 21:18:51 Job still running ...
2023/03/24 21:19:21 Job still running ...
2023/03/24 21:19:51 Job still running ...
2023/03/24 21:20:21 Job still running ...
2023/03/24 21:20:51 Job still running ...
2023/03/24 21:21:21 Job still running ...
2023/03/24 21:21:51 Job still running ...
2023/03/24 21:22:21 Job still running ...
2023/03/24 21:22:51 Job still running ...
2023/03/24 21:23:21 Job still running ...
2023/03/24 21:23:51 Job still running ...
2023/03/24 21:24:21 Job still running ...
2023/03/24 21:24:51 Job still running ...
2023/03/24 21:25:22 Job still running ...
2023/03/24 21:25:52 Job still running ...
2023/03/24 21:26:22 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-24_14_17_50-5829823784135220699 failed
--- FAIL: TestXLang_Partition (551.82s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3264.566s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679689950943321195
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36541 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nHIFtltPtB" is_bounded:BOUNDED windowing_strategy_id:"w0@nHIFtltPtB"}} windowing_strategies:{key:"w0@nHIFtltPtB" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nHIFtltPtB" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nHIFtltPtB" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nHIFtltPtB" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679689950943321195\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nHIFtltPtB"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36541 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nHIFtltPtB" is_bounded:BOUNDED windowing_strategy_id:"w0@nHIFtltPtB"}} windowing_strategies:{key:"w0@nHIFtltPtB" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nHIFtltPtB" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nHIFtltPtB" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nHIFtltPtB" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679689950943321195\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nHIFtltPtB"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000020780})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000020780})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168f40?, 0xc000138230?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc000131660, 0xf}, 0xc0000d5d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168ec0?, 0xc000138230?}, {0xc0005c23c0, 0x52}, {0x1?}, {0xc0000d5ea8, 0x2, 0x7fa274f7bb20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131660, 0xf}, {0xc0005c23c0, 0x52}, {0xebcb60, 0xc00059e200})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000429520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000429520, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.424s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:22401b2fdc029ba92adf92527b5c76746b4f8ff941b8ab9abfbbd594d0714274
Deleted: sha256:c493e2bb9293ed6661f6c77c93dfb8c626815b93ce838f1f20e5bf11444c21c8
Deleted: sha256:4b0979e87ed8c63668a45070a931e9db7cbb09ed2c1b98a3a15e5410d8733eb1
Deleted: sha256:c67a22263093f8847b7bc2c694ecd19db3b238588550bc99814d67870667aae9
Deleted: sha256:60fd7602ced5b4ab4abd5af3ef251c7010cd143b5d866932db17e614e14e6ea5
Deleted: sha256:3d421c2ddd76bea09fefed06ae56af017fda36f657b1b1facedbd8e9732c6846
Deleted: sha256:84a51a719c891545b584749f65916740211be5c881d168454fbd8e1aaf668339
Deleted: sha256:9ad524e78d52a835c8415dad5a4d4f5a61ec95fe6a3d252db9c22e0059ed3711
Deleted: sha256:f9b33845353aa6663b2f9ffaa09302a158f6bf05ce76271c124d04421c455930
Deleted: sha256:a27b1b32cbcdd1615c0ec26397439c8097363f34570425553d6a584f99ecaaf6
Deleted: sha256:3808bedaeeaf3c0df912d8baab3d5bbb0f9af433d1c76d9a061d7af4034de716
Deleted: sha256:7b4541015030e7ad8fdb2071873fa4ce4f7d6e4d6614351beefb4f1ff563314d
Deleted: sha256:53af179b7e83e9f1a49a50c4895830bc727378ddc60260a0c69418c573bc80a0
Deleted: sha256:d9430c0db92e7a575f8346ef1948d74f29557984018f8b556f7c2e692f2a640d
Deleted: sha256:15535eb9732ff1804b7db6b4580930fe92283bfda1e3e9ac3e98a9e4dd7ded36
Deleted: sha256:2e7f9ab315a21b8cb7d6bb07d26375a5c362205b6919c163be6185a3a0b8fe3a
Deleted: sha256:2269f31b61d97119884085020af0558b560bcac1b3d15d9fc60bf96c6ec8dade
Deleted: sha256:e26574b07385a6d0e4fa82fc0e31e0099770d415687ed7184a768e97ae268c5a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:22401b2fdc029ba92adf92527b5c76746b4f8ff941b8ab9abfbbd594d0714274
  Associated tags:
 - 20230324-203147
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-203147].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:22401b2fdc029ba92adf92527b5c76746b4f8ff941b8ab9abfbbd594d0714274].
$ rm -rf /tmp/tmp.zPYE0kfeBh
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324202031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6baf1b965bed23717aef9cea4acfd4defd00516d2e58e6389bf645fe45dd177a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324202031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:80fe63b043453337602c5cb6f1568b7b25652b7bb6f32cef586b1bef9eabf50d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1049264.
Stopping expansion service pid: 1049265.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 56s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1441

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1441/display/redirect>

Changes:


------------------------------------------
[...truncated 674.68 KB...]
keras==2.12.0rc1
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==5.0.1
nltk==3.8.1
nose==1.3.7
numpy==1.23.5
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.7
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pip==23.0.1
pluggy==1.0.0
proto-plus==1.22.2
protobuf==4.22.1
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==4.3.3
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.2
pytest-forked==1.6.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.2
scipy==1.10.1
setuptools==67.6.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.4
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.12.0
tensorboard-data-server==0.7.0
tensorboard-plugin-wit==1.8.1
tensorflow==2.12.0rc1
tensorflow-estimator==2.12.0rc0
tensorflow-io-gcs-filesystem==0.31.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.65.0
typing_extensions==4.5.0
urllib3==1.26.14
websocket-client==1.5.1
Werkzeug==2.2.3
wheel==0.40.0
wrapt==1.14.1
zipp==3.15.0
zstandard==0.20.0
Removing intermediate container a3c38385c536
 ---> 25e430a8b4f3
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> d99d90963e5f
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> a5a8a22297ce
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 8495837466c1
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 7172efa3b553
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 84464cb19600
Removing intermediate container 84464cb19600
 ---> 2975ba00c2e6
Step 22/32 : FROM beam as third_party_licenses
 ---> 2975ba00c2e6
Step 23/32 : ARG pull_licenses
 ---> Running in 524e5c83618a
Removing intermediate container 524e5c83618a
 ---> 63b3adc1d4fe
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 35c18d5e80f3
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> c1372488d008
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in d697a9a5919a
Removing intermediate container d697a9a5919a
 ---> 182f34225954
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 26854c9e4c54
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 151fea51fcee
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=e25c2839748eb6a9d02f558d8cfd71364fb8af3b049b98b897c6272108e6c5fa
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 134 dependencies
Removing intermediate container 151fea51fcee
 ---> 0f0eb60f5aa0
Step 29/32 : FROM beam
 ---> 2975ba00c2e6
Step 30/32 : ARG pull_licenses
 ---> Running in 4debcfe8f359
Removing intermediate container 4debcfe8f359
 ---> ffef422a4170
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 3d566bddf61e
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in ddb1323a3b86
Removing intermediate container ddb1323a3b86
 ---> ef77282026f9
Successfully built ef77282026f9
Successfully tagged apache/beam_python3.8_sdk:2.47.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
2ea22bae5bde: Preparing
a1638633f193: Preparing
b69142c43a30: Preparing
ad9269dd45b7: Preparing
9b178a4175b2: Preparing
1560ed210fbb: Preparing
05ae278bf0cf: Preparing
77252584f7ab: Preparing
190716cd49bc: Preparing
e2f78e3371c8: Preparing
a0756d250b14: Preparing
de8bd4c841a6: Preparing
61358ed3655e: Preparing
1af4478327c8: Preparing
cc8465ede3c6: Preparing
863eba1bb8a1: Preparing
b4f8c0d84a26: Preparing
5c563cc8b216: Preparing
d4514f8b2aac: Preparing
5ab567b9150b: Preparing
190716cd49bc: Waiting
a90e3914fb92: Preparing
e2f78e3371c8: Waiting
053a1f71007e: Preparing
ec09eb83ea03: Preparing
a0756d250b14: Waiting
de8bd4c841a6: Waiting
61358ed3655e: Waiting
863eba1bb8a1: Waiting
cc8465ede3c6: Waiting
05ae278bf0cf: Waiting
1af4478327c8: Waiting
77252584f7ab: Waiting
5c563cc8b216: Waiting
1560ed210fbb: Waiting
d4514f8b2aac: Waiting
5ab567b9150b: Waiting
ec09eb83ea03: Waiting
a90e3914fb92: Waiting
053a1f71007e: Waiting
2ea22bae5bde: Pushed
9b178a4175b2: Pushed
a1638633f193: Pushed
77252584f7ab: Pushed
190716cd49bc: Pushed
1560ed210fbb: Pushed
a0756d250b14: Pushed
b69142c43a30: Pushed
05ae278bf0cf: Pushed
61358ed3655e: Pushed
cc8465ede3c6: Layer already exists
863eba1bb8a1: Layer already exists
b4f8c0d84a26: Layer already exists
5c563cc8b216: Layer already exists
d4514f8b2aac: Layer already exists
5ab567b9150b: Layer already exists
a90e3914fb92: Layer already exists
053a1f71007e: Layer already exists
ec09eb83ea03: Layer already exists
1af4478327c8: Pushed
ad9269dd45b7: Pushed
e2f78e3371c8: Pushed
de8bd4c841a6: Pushed
20230324142041: digest: sha256:edc7a5f363ad8239d983f04d1e8a0e40aaace30fbbcef6b0c3b46a884c6a3ae7 size: 5156

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 11m 21s
223 actionable tasks: 143 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1440

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1440/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324082041",
            "environmentId": "QaTyAyIAvjbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148"
      }
    ]
  },
  "name": "go-testxlang_partition-892",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/24 09:17:19 Submitted job: 2023-03-24_02_17_19-14466495747073985395
2023/03/24 09:17:19 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-24_02_17_19-14466495747073985395?project=apache-beam-testing
2023/03/24 09:17:19 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-24_02_17_19-14466495747073985395
2023/03/24 09:17:19 Job state: JOB_STATE_PENDING ...
2023/03/24 09:17:49 Job still running ...
2023/03/24 09:18:19 Job still running ...
2023/03/24 09:18:49 Job still running ...
2023/03/24 09:19:19 Job still running ...
2023/03/24 09:19:49 Job still running ...
2023/03/24 09:20:19 Job still running ...
2023/03/24 09:20:49 Job still running ...
2023/03/24 09:21:19 Job still running ...
2023/03/24 09:21:49 Job still running ...
2023/03/24 09:22:19 Job still running ...
2023/03/24 09:22:50 Job still running ...
2023/03/24 09:23:20 Job still running ...
2023/03/24 09:23:50 Job still running ...
2023/03/24 09:24:20 Job still running ...
2023/03/24 09:24:50 Job still running ...
2023/03/24 09:25:20 Job still running ...
2023/03/24 09:25:50 Job still running ...
2023/03/24 09:26:20 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-24_02_17_19-14466495747073985395 failed
--- FAIL: TestXLang_Partition (580.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3270.614s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679646743176784678
--- FAIL: TestBigQueryIO_BasicWriteRead (4.34s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36089 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@EcyojSZKKz" is_bounded:BOUNDED windowing_strategy_id:"w0@EcyojSZKKz"}} windowing_strategies:{key:"w0@EcyojSZKKz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@EcyojSZKKz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@EcyojSZKKz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@EcyojSZKKz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679646743176784678\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"EcyojSZKKz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36089 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@EcyojSZKKz" is_bounded:BOUNDED windowing_strategy_id:"w0@EcyojSZKKz"}} windowing_strategies:{key:"w0@EcyojSZKKz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@EcyojSZKKz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@EcyojSZKKz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@EcyojSZKKz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679646743176784678\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"EcyojSZKKz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0000bdac0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0000bdac0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000400c80?, 0xc0001179f0?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9ea20?, 0x1?}, {0xc0001376e0, 0xf}, 0xc000645d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000400c20?, 0xc0001179f0?}, {0xc000118840, 0x52}, {0x1?}, {0xc000645ea8, 0x2, 0x7fb6c5623910?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001376e0, 0xf}, {0xc000118840, 0x52}, {0xebcb60, 0xc0006489f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004fd040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004fd040, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.376s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:26f3f50c14ebf088265bf12486870552dc7f4ee430fc6d2ac29b07e6f6d0cafa
Deleted: sha256:25f2e8b4e1e7699e1382d58a708707b6744e73657bc0488b785e66b72f2ae574
Deleted: sha256:47ce3e6fc8a5a221509bff4092ab5d726ee5a20c02f87b5adffb8c45175ed288
Deleted: sha256:13ec64bf8009d586c0ba96e5d1b44071b8185fd04f52f0b49dc718c04ef45107
Deleted: sha256:f0736df687a405e71ad23dc0110feae9068ca03578539944ebbe11f3d25d7e89
Deleted: sha256:75f7ebe26f761df64a7bd5a330a50228d5324c27fd937af7b913fabbc554c536
Deleted: sha256:e655c6a529c4a4cfc53de86e2d23af4acf508ffdff844c13e2afab4e377f2ce5
Deleted: sha256:27df6f0f7bcfc5af39d084bd001086c6ed5822a91d3d4575845b577b28d4dffe
Deleted: sha256:6c5c13a09d914ef346b0f55e1e7c35b52f079e5c9f2ebac116dc7bfc9176971c
Deleted: sha256:5d2b77a87bf915d0c538c183051493e46e0815f96b0b55595f84eb0ba4f195fc
Deleted: sha256:e719cda9d8a7ef6d99874847c454c899a102cf5ac06202e01dc72a2162c7810d
Deleted: sha256:5e625dae08b3fb9428d2d65ff5ac7ec5d697791ebed67d0d8e160dd76bbb178a
Deleted: sha256:73405c33b5bd5e7492a35094abd2148d15b5c07f5e5de4808f6de6920f685075
Deleted: sha256:c09e996d8a8023be2f06d33b3fbae11f6319bcd67d26d8d1fa766f727a972308
Deleted: sha256:37ed91b5eff869e560805ec624248bfd41c1a0be4b2de4c812140cfc7449c62e
Deleted: sha256:728b92d8b85a9b08a2c642802a3b1081898a9dfb0d1bde4299c007050302dbd0
Deleted: sha256:07e5bf8c1138249a87fc4ce85aaeae1a255601f96f1c8eca8065d18a6c158af9
Deleted: sha256:5ed604412ded6092374de195b832c20199d5f47cd2cfef6edd68bda391056476
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:26f3f50c14ebf088265bf12486870552dc7f4ee430fc6d2ac29b07e6f6d0cafa
  Associated tags:
 - 20230324-083148
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-083148].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:26f3f50c14ebf088265bf12486870552dc7f4ee430fc6d2ac29b07e6f6d0cafa].
$ rm -rf /tmp/tmp.uxHQWYhoBf
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2137f4e570c16c0c49d60e79b7010f22ea36493fb6ef27f4dd9a6006822fea5c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b38955eac5d69e41cab05a6bb13e1a5cc3dbd31550613e9900501ed2debe770f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 696144.
Stopping expansion service pid: 696145.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 34s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1439

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1439/display/redirect>

Changes:


------------------------------------------
[...truncated 1.08 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324022042",
            "environmentId": "DZgcnftaFUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213"
      }
    ]
  },
  "name": "go-testxlang_partition-556",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/24 03:17:54 Submitted job: 2023-03-23_20_17_53-17072204296596431006
2023/03/24 03:17:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-23_20_17_53-17072204296596431006?project=apache-beam-testing
2023/03/24 03:17:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-23_20_17_53-17072204296596431006
2023/03/24 03:17:54 Job state: JOB_STATE_PENDING ...
2023/03/24 03:18:24 Job still running ...
2023/03/24 03:18:54 Job still running ...
2023/03/24 03:19:24 Job still running ...
2023/03/24 03:19:54 Job still running ...
2023/03/24 03:20:24 Job still running ...
2023/03/24 03:20:54 Job still running ...
2023/03/24 03:21:24 Job still running ...
2023/03/24 03:21:54 Job still running ...
2023/03/24 03:22:24 Job still running ...
2023/03/24 03:22:54 Job still running ...
2023/03/24 03:23:24 Job still running ...
2023/03/24 03:23:54 Job still running ...
2023/03/24 03:24:24 Job still running ...
2023/03/24 03:24:54 Job still running ...
2023/03/24 03:25:24 Job still running ...
2023/03/24 03:25:54 Job still running ...
2023/03/24 03:26:24 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-23_20_17_53-17072204296596431006 failed
--- FAIL: TestXLang_Partition (550.85s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3246.422s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679625171731419144
--- FAIL: TestBigQueryIO_BasicWriteRead (4.87s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36973 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RizhTSQqKV" is_bounded:BOUNDED windowing_strategy_id:"w0@RizhTSQqKV"}} windowing_strategies:{key:"w0@RizhTSQqKV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RizhTSQqKV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RizhTSQqKV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RizhTSQqKV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679625171731419144\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RizhTSQqKV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36973 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RizhTSQqKV" is_bounded:BOUNDED windowing_strategy_id:"w0@RizhTSQqKV"}} windowing_strategies:{key:"w0@RizhTSQqKV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RizhTSQqKV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RizhTSQqKV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RizhTSQqKV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679625171731419144\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RizhTSQqKV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00066f380})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00066f380})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7040?, 0xc0003f6050?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000124d00, 0xf}, 0xc000199d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6fa0?, 0xc0003f6050?}, {0xc00004ca20, 0x52}, {0x1?}, {0xc000199ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000124d00, 0xf}, {0xc00004ca20, 0x52}, {0xebcb60, 0xc00058e138})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103a00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.900s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.055s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:961756f20818cd1fd11ba35bee9d27133c712771279cbe36ef954b71cd5ee163
Deleted: sha256:37c5848e1303e51780de26e3fe034941e49fced56d709176d268c7ccd163fd3d
Deleted: sha256:156ece1fa90037b2892eaf6e63b38aef619b0d980888d54851021dcbea159c56
Deleted: sha256:43317240a301d5e868fa8341a897dae2c61ccf9df13d50f7e03543167aca4790
Deleted: sha256:3dc6c0ed2acc82cfca0c03872e182efe695c6206f79b55967732b75e7449e46b
Deleted: sha256:5cb40e7e4c9ab7c2480601385ac6165f1df9ce6b16e2f89da690a8cd2f7ba721
Deleted: sha256:d21c89bd6315439dfb696d054da3b98d3b1f309e0993fc6d000bc69a310fb8c3
Deleted: sha256:cf2eb9066585ce12a92c17bc8240409baf71b14e420f9e309052a3333f75be87
Deleted: sha256:d417b47f37a0c12e08fa204d3ce7f2237132db8d8d72d974e15b80527a48a216
Deleted: sha256:fb4d4eb54b89abb4af760d73202fbc44acaf1faea9d0e556fa88d380a0cd6979
Deleted: sha256:da563b2a489b57899ab4e684d3cfa073f3ce6ea9e8b5fd911ec81ae7e355b8f9
Deleted: sha256:db69e44a150f473bcb132f007fe309db99898bb3ce9f05ee29efb289f0795d69
Deleted: sha256:ae8706f5ba369f6996f80c42ec19a7f64439b3eeaadb607b5b7bcad9f7c4398e
Deleted: sha256:1e70019501b6a68d4ffbd9940975fc72361f460b1b0b6598e25b6eb8c55b6a26
Deleted: sha256:25de7ec0ec18048360cba45fac6ca12f83f1d0d0b8bd118531e9d043c2f19e26
Deleted: sha256:f451d967a59bfa0f2f12455d7fe4111e53427dca909af3e1409c9148c1edc5b7
Deleted: sha256:122df34cbcbd32b678ee5d7e6797b67170bdbd5fe74dd869e4d382d47745fa51
Deleted: sha256:e891478b4e6375efcc26d0e70cab066e915e7192757aa5e303d3fa2e19c85cc3
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:961756f20818cd1fd11ba35bee9d27133c712771279cbe36ef954b71cd5ee163
  Associated tags:
 - 20230324-023213
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230324-023213].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:961756f20818cd1fd11ba35bee9d27133c712771279cbe36ef954b71cd5ee163].
$ rm -rf /tmp/tmp.e76ODuQB8u
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324022042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230324022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3c5a94749cad1ad245ce2058bf394b37205a8d205997076eca4997444cae66f8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324022042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230324022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:932cae2458932fa7b7014e6160bdea92c539870efbcc20b5353f2de3fddef9c9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 564831.
Stopping expansion service pid: 564832.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 38s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1438

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1438/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
2023/03/23 21:27:29 Job still running ...
2023/03/23 21:27:59 Job still running ...
2023/03/23 21:28:29 Job still running ...
2023/03/23 21:28:59 Job still running ...
2023/03/23 21:29:29 Job still running ...
2023/03/23 21:29:59 Job still running ...
2023/03/23 21:30:29 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-23_14_20_58-7753462487578753083 failed
--- FAIL: TestXLang_Partition (615.23s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3341.956s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679603723767152197
--- FAIL: TestBigQueryIO_BasicWriteRead (5.36s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42315 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cfujnbcFSY" is_bounded:BOUNDED windowing_strategy_id:"w0@cfujnbcFSY"}} windowing_strategies:{key:"w0@cfujnbcFSY" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cfujnbcFSY" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cfujnbcFSY" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cfujnbcFSY" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679603723767152197\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cfujnbcFSY"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42315 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cfujnbcFSY" is_bounded:BOUNDED windowing_strategy_id:"w0@cfujnbcFSY"}} windowing_strategies:{key:"w0@cfujnbcFSY" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cfujnbcFSY" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cfujnbcFSY" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cfujnbcFSY" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679603723767152197\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cfujnbcFSY"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00040ccc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00040ccc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004080a0?, 0xc000542000?}, {0x113b23e, 0x39}, {0xc000450000?, 0xa9ea20?, 0x1?}, {0xc0004ceb60, 0xf}, 0xc000145d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000408020?, 0xc000542000?}, {0xc00004c960, 0x52}, {0x1?}, {0xc000145ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0004ceb60, 0xf}, {0xc00004c960, 0x52}, {0xebcb60, 0xc00040a198})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003e1380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003e1380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.389s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-203433
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-203433
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:81911fda7d016d762854fb99d48492d1189552d300f69864dff024312a8530e9
Deleted: sha256:8e8c517eaac32eb0d7239c83b53b64d1059cf2245078514b56051f59676dc447
Deleted: sha256:005f1989af42cfd94ba0e55153f43f90b35c339bd064b51d381fda504d1aca3e
Deleted: sha256:a465062547e6df8f2fe703e061bb0323357c316523b34ed5dbad2010929d4b0e
Deleted: sha256:fa09aa0fe6f33d951d4cfe7cb7eb63bfe671fff66a1682db4001a620a433bac3
Deleted: sha256:4219059a2e3276a34315901350a13de759fc213ff212fd785be613cf887d25a2
Deleted: sha256:ca2e4fea6d7023cd68e96c99f2f0d35f5d13c0985e0e13c2f20654db22614d34
Deleted: sha256:d3a6464ad61bb3db2be6f63bca1357daa39b41a610e5573784320078015268ff
Deleted: sha256:29531367a8d672597779af30e6c398d57a536368e9a00bb93508bbb2f06cc2c5
Deleted: sha256:9abbd86de1709ed91666b8416cca154955520f36d8bae428a04440430c0ad1e2
Deleted: sha256:6f04aa96e8320c10fedc4a6f57ac0363293dd03c9fb943ff2075c688ebc886d1
Deleted: sha256:8840e06b0c957116160df490741cc07c5e7a3b369b896d2c2aeef17832537014
Deleted: sha256:55dd1c5bc78f031861251d425a6a871f59baecdb342674865dc7c81850f73bd4
Deleted: sha256:7115e4a1fe98b3a45d846ab633dade149d35360226710aec42ea1c93238640f6
Deleted: sha256:d0d8d143fa50848e336485b34bd2273d6b94e47466e22312b7f2d5bffc7a409b
Deleted: sha256:391e1671842d9940e08f58ea8b9ac2c4d03b266089ba2f62888c71ebe44c6aef
Deleted: sha256:0da149f31d265abc5d391e85f52531f96dfb06bf08a177ad93b85b6efd9eea79
Deleted: sha256:fb95a96e8d1534a413922c19116b8aee0f555e821926aede43d3766d9bdaf2d6
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-203433
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:81911fda7d016d762854fb99d48492d1189552d300f69864dff024312a8530e9
  Associated tags:
 - 20230323-203433
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-203433
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-203433].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:81911fda7d016d762854fb99d48492d1189552d300f69864dff024312a8530e9].
$ rm -rf /tmp/tmp.aMNEOrYGkZ
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323202058
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323202058]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323202058] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b69309d8f08a3c9ac302b420779752bdf9bef872ea4ba52b957e5b3026b144f0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323202058
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f
Deleted: sha256:62dc57b50a711b66ff7aa808bc835f706d23fd84956f4419ebbad0f13eb2e790
Deleted: sha256:754cb6186d1fb73bef32e42737a1b8a34ce9cc708f2809d3dc0f1a1dbce9dd6a
Deleted: sha256:e00d09acc4396fa76c0995f5b942216e314a715ba86a753a9ad1cc13bc3b2dd1
Deleted: sha256:8e44e85293695c0ae79f7fb30968e20a4addbca5149f2230056185553d7b9d0b
Deleted: sha256:7817b5bc3e4fca3785b016e673bbf2501b12566915df4d557e1841c7d9c2d57d
Deleted: sha256:8b69809b4365247130c8951cd2e3a230085cdf4461e09bb5d11a8d5334ffc869
Deleted: sha256:8cf715e7b4c769cd40cb0c48616f9cbafb641144d65e3355875f4272b27dd6f7
Deleted: sha256:7f71ea18bde658edf0a3394676cc441aa279ddb85ad27af22a4e6f1490dcc40d
Deleted: sha256:d4941433955945dec918028d2f79dfe2b98b6eb2f9e2c7abedcdfbb96d30e00a
Deleted: sha256:a601e4c913d9707625c418ba7aca4f2cb19902333c5152a37b04e4c06752ec91
Deleted: sha256:1b56497671c6a0c4c2a39e9572eed0d3a95486f527596f7a83d76db53f822b0d
Deleted: sha256:beb2fbd9c1796c3f5c9c15de6222f539944ae1f338f88112dc32d94d7676ac23
Deleted: sha256:23b84ebc8e316cc3c7d1894da9e53ebc5f622f4d588dbb94da7e5e5393634031
Deleted: sha256:fefc00c6ef37ccfb37bbdedaa057bb2e7ebcdb56ffa5cb77526b34ebb7f65b05
Deleted: sha256:71eb9e08e0e1c45e678b27d863c72a97e1f8df0f2eb2a0bbc63497ec038a2f5c
Deleted: sha256:0a96eb2c0c21a58c796df8a8b6c7f2bae36f6b651faa62d6f70c3f1fbce602fa
Deleted: sha256:ff91768deda7736722b83a8618c42bff26a22f30431a134352e04d6de6b54354
Deleted: sha256:b03eed4779a3aae2711e4b6c7c57f12c65e2b5277471024ef315fa1c5a710081
Deleted: sha256:9a93f06d68d011cadecdf9e2a271c6ce9df8bfcedc02516bd78b2370875af4bb
Deleted: sha256:9fb0eb612b35fdff3b4f774264905066648f39be66148dfc3c4e7515213faf40
Deleted: sha256:77c4108135366cb261889e6bfebbed2e90f10a0bba28131f54dacea2e6d914ce
Deleted: sha256:0afff880cbd165ceda99c7744b4638de9f5c2868d3ba496eaa63dae9d532e8e1
Deleted: sha256:3315f3a29d30969fc7c1bccc96ef2fd9cb1bb4cf4e77fd9c5dc3ed5591956396
Deleted: sha256:87040044f7cb1c027c29fef2b0725b713c57cd802c44880ec32cda87a04be2e9
Deleted: sha256:760204bfcb1759d334285faa5bee26a4ed709ebb9454106d078a6729e529f09b
Deleted: sha256:94ce8c908cfe794063bd526af8a6002119def2d7ca6a2bd98ecaf07bcb62f968
Deleted: sha256:d54a73ae9156dba0e3a2fbf0dc02c3811b32dea9f593c7b52525bfb629626534
Deleted: sha256:c79dbaaa22506614a39d4dc511d0b217bb82d4490b7eb41d8d0a8715f265a440
Deleted: sha256:2a8d594a518591fc33d4e6088a3a00208b7fd8674128330670ff0baa892b60c4
Deleted: sha256:01b3a71604fe235d69e28c502caa1762b62e868ab424687195ec1bc93e0741e1
Deleted: sha256:295d12f15aeff8da18ae596c51e176a254db4c6ca20e4eee4b94cee2211fd595
Deleted: sha256:f6678acaca2c6b86270ed6feb5037ccae8d8df7413a2e873a73691e32c0d3c2c
Deleted: sha256:b2cbc762c4a25152f93cafe1d660e36a0ff3ab520cf34905c3bf4982bc5f0d8c
Deleted: sha256:4f9e97a1081b6bd46a9ae538250d6fa0a19de3256906da3e1b40c7aec265f318
Deleted: sha256:30bd4bfcb4150d67ac88a60d097d74e094755e08b2d3643014bd41859236f2ba
Deleted: sha256:2249facef6403464393e8f145e8ca6fbdaae44cca2cef2b83844c3fcbfcb5a9b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323202058]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323202058] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2cc2ca4fdc0a71852da475f8678b854d942db3c26bfc587de1dab546fa247f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 724753.
Stopping expansion service pid: 724754.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 48s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1437

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1437/display/redirect?page=changes>

Changes:

[noreply] Fix Illegal to use destination for jms producer (#25886)


------------------------------------------
[...truncated 581.17 KB...]
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323142041",
            "environmentId": "KqQYfeuCmTbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249"
      }
    ]
  },
  "name": "go-testxlang_partition-677",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/23 15:19:29 Submitted job: 2023-03-23_08_19_28-7316370230569907872
2023/03/23 15:19:29 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-23_08_19_28-7316370230569907872?project=apache-beam-testing
2023/03/23 15:19:29 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-23_08_19_28-7316370230569907872
2023/03/23 15:19:29 Job state: JOB_STATE_PENDING ...
2023/03/23 15:19:59 Job still running ...
2023/03/23 15:20:29 Job still running ...
2023/03/23 15:20:59 Job still running ...
2023/03/23 15:21:29 Job still running ...
2023/03/23 15:21:59 Job still running ...
2023/03/23 15:22:29 Job still running ...
2023/03/23 15:22:59 Job still running ...
2023/03/23 15:23:29 Job still running ...
2023/03/23 15:23:59 Job still running ...
2023/03/23 15:24:29 Job still running ...
2023/03/23 15:24:59 Job still running ...
2023/03/23 15:25:29 Job still running ...
2023/03/23 15:25:59 Job still running ...
2023/03/23 15:26:30 Job still running ...
2023/03/23 15:27:00 Job still running ...
2023/03/23 15:27:30 Job still running ...
2023/03/23 15:28:00 Job still running ...
2023/03/23 15:28:30 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-23_08_19_28-7316370230569907872 failed
--- FAIL: TestXLang_Partition (581.69s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3336.174s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679582007226385428
--- FAIL: TestBigQueryIO_BasicWriteRead (4.59s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MbmUDGEzzi" is_bounded:BOUNDED windowing_strategy_id:"w0@MbmUDGEzzi"}} windowing_strategies:{key:"w0@MbmUDGEzzi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MbmUDGEzzi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MbmUDGEzzi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MbmUDGEzzi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679582007226385428\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MbmUDGEzzi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MbmUDGEzzi" is_bounded:BOUNDED windowing_strategy_id:"w0@MbmUDGEzzi"}} windowing_strategies:{key:"w0@MbmUDGEzzi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MbmUDGEzzi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MbmUDGEzzi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MbmUDGEzzi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679582007226385428\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MbmUDGEzzi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 69 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0005c7100})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0005c7100})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003e00e0?, 0xc0000cc230?}, {0x113b23e, 0x39}, {0xc000150000?, 0xa9ea20?, 0x1?}, {0xc00012a010, 0xf}, 0xc00061fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003e0040?, 0xc0000cc230?}, {0xc000118360, 0x52}, {0x1?}, {0xc00061fea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00012a010, 0xf}, {0xc000118360, 0x52}, {0xebcb60, 0xc00056e008})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006009c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006009c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.628s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:44cbaff17b08b895bcdbc48093695e97e9893141bde6df7b37753560d762112a
Deleted: sha256:0a5fb29f0af033cae52ba4809e1c2aafafc950d4b8c7814f8930b90ecddcf901
Deleted: sha256:ad9901965d30a38a92e750fc792c4eac148bf0987a34c23fc21e0788e1a46f45
Deleted: sha256:5047d37570a50dcf7a0fe50934b37e17d26a0ebb9952657dd69437326c1fc49d
Deleted: sha256:5c4aacfbce069237ba21adc4138357286e0bcc3bb820d69646cd5786d4997508
Deleted: sha256:cab4d2a430c11406dbc5efd9d12d63397565bd17584965295e8d8760af0a5512
Deleted: sha256:7d5d6719e9a41cff2226e49d847cb0f913e536ae6bd198c624570cb998d0d490
Deleted: sha256:9bcaa57ba40fa28f4e4e17d50b38471cd8683ab2faba4ba9e9033ab2343aed60
Deleted: sha256:09c5517d6ae2076a026d20377311d79dd7aae7ad071a52c10193b5b8ddfe4755
Deleted: sha256:ee0d581f3037e61e1a4112cbed553d51cbb93829ad1a0a8cb1ca68e3e0e94e07
Deleted: sha256:b93342a087947157cd35eb10013776c0e03ffd3ae54ae31012fc76a6936f0158
Deleted: sha256:0e695684e505a059c367f29a2b2e7ed92f49d097b385ef7689a1e474a8ec7579
Deleted: sha256:64b478d374933cc75f3b3bc576b01cbf89335ffd126523dd0948271be196228e
Deleted: sha256:7df35f9b253f6c3c921cc9d199a2fb127b1bd7ce652c701cee2af373598b2f90
Deleted: sha256:418c3df1f05fb6eb2b198c1b654d85d5ad10bdb44057f36bb0e5bf69ddcab8af
Deleted: sha256:dc118d6590e3d6b874b55d82af121b3a60208fd689faf2a5f93024120c2830c9
Deleted: sha256:fc708e57c7d0453810076926f8a4da93c16821adb0b2b0f4fed9ff772bb4b0b8
Deleted: sha256:b38d789914b43c91ba5d8305b9b4453fae91a052a86c8f2f0429be66d26ceb87
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:44cbaff17b08b895bcdbc48093695e97e9893141bde6df7b37753560d762112a
  Associated tags:
 - 20230323-143249
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-143249].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:44cbaff17b08b895bcdbc48093695e97e9893141bde6df7b37753560d762112a].
$ rm -rf /tmp/tmp.W851DvzTnB
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35
Deleted: sha256:b5cc58e624480630bb69bbaeba5b5caca493af01808925b370471bd6198dcb31
Deleted: sha256:d1127aa1860709b9519f78225eab9344e2b83ffa89bef873fc3799a360bacde1
Deleted: sha256:0629c9024ad8a0bc962c9d5ba73da16ca7504c93c1b180fe523d711e37eb67c4
Deleted: sha256:cc092e8d0ea5646a460eb71ed734e3b612c723b1ccd6944de1986c8e9985a295
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a3d0b5d638b7ebbec1a45de6939ab165b78b325c6743a9274109caf8c482ed35].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb726e0833f6e96a7b75b2a65922ae879293cfa51d0de448cff005b6a5728d7b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 4019770.
Stopping expansion service pid: 4019771.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 56s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/4otaxm32zfvxo

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1436

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1436/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323082041",
            "environmentId": "VICvvzJWIObeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201"
      }
    ]
  },
  "name": "go-testxlang_partition-400",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/23 09:17:36 Submitted job: 2023-03-23_02_17_36-10372432621191471203
2023/03/23 09:17:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-23_02_17_36-10372432621191471203?project=apache-beam-testing
2023/03/23 09:17:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-23_02_17_36-10372432621191471203
2023/03/23 09:17:36 Job state: JOB_STATE_PENDING ...
2023/03/23 09:18:06 Job still running ...
2023/03/23 09:18:36 Job still running ...
2023/03/23 09:19:06 Job still running ...
2023/03/23 09:19:36 Job still running ...
2023/03/23 09:20:07 Job still running ...
2023/03/23 09:20:37 Job still running ...
2023/03/23 09:21:07 Job still running ...
2023/03/23 09:21:37 Job still running ...
2023/03/23 09:22:07 Job still running ...
2023/03/23 09:22:37 Job still running ...
2023/03/23 09:23:07 Job still running ...
2023/03/23 09:23:37 Job still running ...
2023/03/23 09:24:07 Job still running ...
2023/03/23 09:24:37 Job still running ...
2023/03/23 09:25:07 Job still running ...
2023/03/23 09:25:37 Job still running ...
2023/03/23 09:26:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-23_02_17_36-10372432621191471203 failed
--- FAIL: TestXLang_Partition (550.67s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.198s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679560359806517743
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35445 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oNoWlPXBdZ" is_bounded:BOUNDED windowing_strategy_id:"w0@oNoWlPXBdZ"}} windowing_strategies:{key:"w0@oNoWlPXBdZ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oNoWlPXBdZ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oNoWlPXBdZ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oNoWlPXBdZ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679560359806517743\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oNoWlPXBdZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35445 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oNoWlPXBdZ" is_bounded:BOUNDED windowing_strategy_id:"w0@oNoWlPXBdZ"}} windowing_strategies:{key:"w0@oNoWlPXBdZ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oNoWlPXBdZ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oNoWlPXBdZ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oNoWlPXBdZ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679560359806517743\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oNoWlPXBdZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 29 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0002ab300})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0002ab300})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6ea0?, 0xc0000bd6d0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc000042db0, 0xf}, 0xc00019dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6e40?, 0xc0000bd6d0?}, {0xc00004c540, 0x52}, {0x1?}, {0xc00019dea8, 0x2, 0x7f90acde7a78?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042db0, 0xf}, {0xc00004c540, 0x52}, {0xebcb60, 0xc0002260c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cab60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cab60, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.475s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f4601069545ec0913b32bacfe73f185ded11d92f885f7836f017b40377c3cb61
Deleted: sha256:bd6658087be6506b5e17bf6b8535010833c7e7623567511ea2c3690efa4548b2
Deleted: sha256:625e5dd39d4e6fc184d0cd23433fa5aaf650cd55a02d46b91f4881fdddf25eb2
Deleted: sha256:2a5756d2e8c98c36eb4c126363539da43ec201fcc97d2d962db5ccd6e047de8b
Deleted: sha256:4a5e7e0e2df720348fa3fe232cf7b85bf911b3528a97bc3bf0743d50e6d6208b
Deleted: sha256:b1642256dd078e3500c679fccfde57e3cf84ffc2e62e2d40a0ca7bee98cdc4c0
Deleted: sha256:ed82f2e09ccd198e12ac3106299f5b4907add715e106da2fb3be4cc0058d821a
Deleted: sha256:2f308f3d5aa9188d3e6fdc9a1b7980f7364d96c62287ebfd62eb6615f9a3d8a7
Deleted: sha256:1e71da29dbf36369f032425044e5d2d94f883855282efc2952eaf729b98cd1aa
Deleted: sha256:1590cc0b3dfd19d915813fdc4b4cbb69f83e16b56c15c9f31b5b4a4589d40645
Deleted: sha256:61f1eb66c724d3ec2afe4542869b02a0537a5af9444e1e195bdb2555358240a1
Deleted: sha256:51f7a4559fe29f88f12a696a054fe6ad4c981924721f2b9ed7d093ac22980d6b
Deleted: sha256:0fa93f5aa2271cb44ed39e1d015157d2dfbee84aed57a18619e5f05e27da53d0
Deleted: sha256:8879722eb96c1031b3b38f8b6247c822ab57a94c267a23398eb5fa81b4b5ec2f
Deleted: sha256:02dc0c7073ad9b654c55e48b06ac59f330394058f408574906855c7f31881ecf
Deleted: sha256:8f7f67c1a766e06c5aeca3560a893c2e379828dd28f2059366afc99b2633937f
Deleted: sha256:c96c5b964e6c26fd0766327c04374e8b3f09008de72f6b3f94ebfc22c2dc83fc
Deleted: sha256:e44c0319a26889834a3a1829fb4717c785ea8c513bb4231056abc0457f389f59
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f4601069545ec0913b32bacfe73f185ded11d92f885f7836f017b40377c3cb61
  Associated tags:
 - 20230323-083201
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-083201].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f4601069545ec0913b32bacfe73f185ded11d92f885f7836f017b40377c3cb61].
$ rm -rf /tmp/tmp.mQ7Gt4iDOJ
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89cd0a26fbd094c2f1faede4ffbb4a78f4f8e3cd6960b3e8fd9e9cfd99493059].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323082041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d4e63de05962708c62a43853741f914205dbb8688e964c4154028fee019d05aa].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3665168.
Stopping expansion service pid: 3665169.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 31s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1435

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1435/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-023140",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323022027",
            "environmentId": "pNRBQaAMsVbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-023140"
      }
    ]
  },
  "name": "go-testxlang_partition-875",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/23 03:17:42 Submitted job: 2023-03-22_20_17_42-5731930371466602319
2023/03/23 03:17:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-22_20_17_42-5731930371466602319?project=apache-beam-testing
2023/03/23 03:17:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-22_20_17_42-5731930371466602319
2023/03/23 03:17:42 Job state: JOB_STATE_PENDING ...
2023/03/23 03:18:12 Job still running ...
2023/03/23 03:18:42 Job still running ...
2023/03/23 03:19:12 Job still running ...
2023/03/23 03:19:43 Job still running ...
2023/03/23 03:20:13 Job still running ...
2023/03/23 03:20:43 Job still running ...
2023/03/23 03:21:13 Job still running ...
2023/03/23 03:21:43 Job still running ...
2023/03/23 03:22:13 Job still running ...
2023/03/23 03:22:43 Job still running ...
2023/03/23 03:23:13 Job still running ...
2023/03/23 03:23:43 Job still running ...
2023/03/23 03:24:13 Job still running ...
2023/03/23 03:24:43 Job still running ...
2023/03/23 03:25:13 Job still running ...
2023/03/23 03:25:43 Job still running ...
2023/03/23 03:26:13 Job still running ...
2023/03/23 03:26:43 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-22_20_17_42-5731930371466602319 failed
--- FAIL: TestXLang_Partition (582.14s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3300.462s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679538736542961790
--- FAIL: TestBigQueryIO_BasicWriteRead (5.17s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41467 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@OVHhiNRffj" is_bounded:BOUNDED windowing_strategy_id:"w0@OVHhiNRffj"}} windowing_strategies:{key:"w0@OVHhiNRffj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@OVHhiNRffj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@OVHhiNRffj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@OVHhiNRffj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679538736542961790\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"OVHhiNRffj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41467 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@OVHhiNRffj" is_bounded:BOUNDED windowing_strategy_id:"w0@OVHhiNRffj"}} windowing_strategies:{key:"w0@OVHhiNRffj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@OVHhiNRffj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@OVHhiNRffj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@OVHhiNRffj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679538736542961790\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"OVHhiNRffj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0001740c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0001740c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e1aa0?, 0xc000139720?}, {0x113b23e, 0x39}, {0xc0001d20c0?, 0xa9ea20?, 0x1?}, {0xc000042d80, 0xf}, 0xc000535d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e1a40?, 0xc000139720?}, {0xc000180900, 0x52}, {0x1?}, {0xc000535ea8, 0x2, 0x7ff5a409c188?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d80, 0xf}, {0xc000180900, 0x52}, {0xebcb60, 0xc000542090})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c8ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c8ea0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.205s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.051s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68ddd7733dc8c62d0d7d2e76253494276f4346de47cb1bd205156c5c1b9b3b56
  Associated tags:
 - 20230323-023140
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-023140
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230323-023140].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68ddd7733dc8c62d0d7d2e76253494276f4346de47cb1bd205156c5c1b9b3b56].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323022027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1d7439def4f2a55a023aec43223b4c0cff35f81b125e9b1889709efe66d2de7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230323022027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1d7439def4f2a55a023aec43223b4c0cff35f81b125e9b1889709efe66d2de7])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1d7439def4f2a55a023aec43223b4c0cff35f81b125e9b1889709efe66d2de7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1d7439def4f2a55a023aec43223b4c0cff35f81b125e9b1889709efe66d2de7].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323022027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:edefb8de4683192d53bd9078219317906fd3444128f4f4644dab9ef738902489]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230323022027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:edefb8de4683192d53bd9078219317906fd3444128f4f4644dab9ef738902489])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:edefb8de4683192d53bd9078219317906fd3444128f4f4644dab9ef738902489
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:edefb8de4683192d53bd9078219317906fd3444128f4f4644dab9ef738902489].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 11s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1434

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1434/display/redirect?page=changes>

Changes:

[noreply] Adds multi-language Python and Java quickstart release validations


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-203201",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322202041",
            "environmentId": "eePVtMPVoZbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-203201"
      }
    ]
  },
  "name": "go-testxlang_partition-955",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/22 21:18:16 Submitted job: 2023-03-22_14_18_15-17074434340333327559
2023/03/22 21:18:16 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-22_14_18_15-17074434340333327559?project=apache-beam-testing
2023/03/22 21:18:16 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-22_14_18_15-17074434340333327559
2023/03/22 21:18:16 Job state: JOB_STATE_PENDING ...
2023/03/22 21:18:46 Job still running ...
2023/03/22 21:19:16 Job still running ...
2023/03/22 21:19:46 Job still running ...
2023/03/22 21:20:16 Job still running ...
2023/03/22 21:20:46 Job still running ...
2023/03/22 21:21:16 Job still running ...
2023/03/22 21:21:46 Job still running ...
2023/03/22 21:22:16 Job still running ...
2023/03/22 21:22:46 Job still running ...
2023/03/22 21:23:16 Job still running ...
2023/03/22 21:23:46 Job still running ...
2023/03/22 21:24:16 Job still running ...
2023/03/22 21:24:46 Job still running ...
2023/03/22 21:25:16 Job still running ...
2023/03/22 21:25:46 Job still running ...
2023/03/22 21:26:16 Job still running ...
2023/03/22 21:26:47 Job still running ...
2023/03/22 21:27:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-22_14_18_15-17074434340333327559 failed
--- FAIL: TestXLang_Partition (582.22s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3304.071s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679517166161485370
--- FAIL: TestBigQueryIO_BasicWriteRead (4.41s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45217 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@sbEHMgoOYz" is_bounded:BOUNDED windowing_strategy_id:"w0@sbEHMgoOYz"}} windowing_strategies:{key:"w0@sbEHMgoOYz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@sbEHMgoOYz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@sbEHMgoOYz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@sbEHMgoOYz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679517166161485370\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"sbEHMgoOYz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45217 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@sbEHMgoOYz" is_bounded:BOUNDED windowing_strategy_id:"w0@sbEHMgoOYz"}} windowing_strategies:{key:"w0@sbEHMgoOYz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@sbEHMgoOYz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@sbEHMgoOYz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@sbEHMgoOYz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679517166161485370\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"sbEHMgoOYz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0000f28c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0000f28c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000510440?, 0xc000416050?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9ea20?, 0x1?}, {0xc000042d70, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005103e0?, 0xc000416050?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7fd34019dc58?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d70, 0xf}, {0xc00004c5a0, 0x52}, {0xebcb60, 0xc0005120c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ccea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ccea0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.439s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cd98efa70a5913da23c4455d61234ba06b35618a3c920aeb8ccf279b8d434a57
  Associated tags:
 - 20230322-203201
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-203201
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-203201].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cd98efa70a5913da23c4455d61234ba06b35618a3c920aeb8ccf279b8d434a57].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0095c3a05b1ed7d20a06fac45faf8baf417ef9289f5ee704cb807d953dc68b7c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0095c3a05b1ed7d20a06fac45faf8baf417ef9289f5ee704cb807d953dc68b7c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0095c3a05b1ed7d20a06fac45faf8baf417ef9289f5ee704cb807d953dc68b7c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0095c3a05b1ed7d20a06fac45faf8baf417ef9289f5ee704cb807d953dc68b7c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb955dca8952a42ed98fb28b38d57b7db531574d5e8390c150f457ab5fac984f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb955dca8952a42ed98fb28b38d57b7db531574d5e8390c150f457ab5fac984f])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb955dca8952a42ed98fb28b38d57b7db531574d5e8390c150f457ab5fac984f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eb955dca8952a42ed98fb28b38d57b7db531574d5e8390c150f457ab5fac984f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 35s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/27ktkd2w3cxcq

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1433

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1433/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322142040",
            "environmentId": "zJvmBhmOgKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200"
      }
    ]
  },
  "name": "go-testxlang_partition-185",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/22 15:17:34 Submitted job: 2023-03-22_08_17_34-17364139839607860895
2023/03/22 15:17:34 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-22_08_17_34-17364139839607860895?project=apache-beam-testing
2023/03/22 15:17:34 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-22_08_17_34-17364139839607860895
2023/03/22 15:17:34 Job state: JOB_STATE_PENDING ...
2023/03/22 15:18:04 Job still running ...
2023/03/22 15:18:34 Job still running ...
2023/03/22 15:19:04 Job still running ...
2023/03/22 15:19:34 Job still running ...
2023/03/22 15:20:04 Job still running ...
2023/03/22 15:20:34 Job still running ...
2023/03/22 15:21:04 Job still running ...
2023/03/22 15:21:34 Job still running ...
2023/03/22 15:22:04 Job still running ...
2023/03/22 15:22:34 Job still running ...
2023/03/22 15:23:05 Job still running ...
2023/03/22 15:23:35 Job still running ...
2023/03/22 15:24:05 Job still running ...
2023/03/22 15:24:35 Job still running ...
2023/03/22 15:25:05 Job still running ...
2023/03/22 15:25:35 Job still running ...
2023/03/22 15:26:05 Job still running ...
2023/03/22 15:26:35 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-22_08_17_34-17364139839607860895 failed
--- FAIL: TestXLang_Partition (581.61s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3273.114s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679495555719652445
--- FAIL: TestBigQueryIO_BasicWriteRead (4.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33315 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@eOxLQfjjfw" is_bounded:BOUNDED windowing_strategy_id:"w0@eOxLQfjjfw"}} windowing_strategies:{key:"w0@eOxLQfjjfw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@eOxLQfjjfw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@eOxLQfjjfw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@eOxLQfjjfw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679495555719652445\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"eOxLQfjjfw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33315 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@eOxLQfjjfw" is_bounded:BOUNDED windowing_strategy_id:"w0@eOxLQfjjfw"}} windowing_strategies:{key:"w0@eOxLQfjjfw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@eOxLQfjjfw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@eOxLQfjjfw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@eOxLQfjjfw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679495555719652445\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"eOxLQfjjfw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 30 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00058b8c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00058b8c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003f0220?, 0xc000654000?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9ea20?, 0x1?}, {0xc000582ca0, 0xf}, 0xc000579d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003f01c0?, 0xc000654000?}, {0xc000554300, 0x52}, {0x1?}, {0xc000579ea8, 0x2, 0x7fbe39814fe8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000582ca0, 0xf}, {0xc000554300, 0x52}, {0xebcb60, 0xc0004800a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006429c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006429c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.599s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a48807701a694747e138f5d3243dffa81b475d3e5f722b6c11875150a4a30910
Deleted: sha256:5a07113e04ea800b470d5cd20d2a42176d384aaf7ffaee35163f83927d86325e
Deleted: sha256:e67252e1e6c0817545348c41070c982467fc844e279f759656f41caebbc124b6
Deleted: sha256:f8ef11090cd1492e528e9f2422cec896c061a9de54e6b1261a796702c1340c5f
Deleted: sha256:92413a18e49e9f3c21e90ebc3cf420b829ad60232db819c2343212b94e6472d6
Deleted: sha256:db8079d5b51a93ebcc71c51c5fac7cfe6cdd1743d699f4bae3491899a620f5dd
Deleted: sha256:7b56d022f91afdcaafd27d459207164672fe3411a281474a6b3fb4c1fff24ce9
Deleted: sha256:9906d0a56fd7fa1e8ebd636df012e109ccdbe1ebfe03685f9040c851f4d60daf
Deleted: sha256:ade413cb4d30a79c554ee00c2cee44bb113e5408c4e9faec2c9493eb3bf9461f
Deleted: sha256:7524d4c772e7df70392480f039593277fb7802849688c805025dcf3885bb62cd
Deleted: sha256:597956b50b9e6e3527c2011c0c4be3d00fdc48511e859652be1ec60e6b054901
Deleted: sha256:b0eebb005f5b4b875174832470c139f1b4c166bdcddde89262c4ede41d2faa79
Deleted: sha256:a1395485675f7bb62abfe1688b2a246452826733c6566252421c16e676c8177e
Deleted: sha256:3e867ed20faffbb11eb4e14eb864aaa61b34c9248142d842470dd9aa0a5252c0
Deleted: sha256:00c1fe99eb29442918c00171afa8c75a1839c1080f489d5a9e1f247b924d827f
Deleted: sha256:bffe5afda079430e27d14e9974969b3b2c1183810db34dedb4b51f78dae674fc
Deleted: sha256:fa6eae4a91173e5637578083cf058e076041538a4e10863c46056d10ca032b64
Deleted: sha256:7e8dc6f22c93c78dad49bd2129a0db9aa518d71a3562d1f0366e0b6bb8e78883
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a48807701a694747e138f5d3243dffa81b475d3e5f722b6c11875150a4a30910
  Associated tags:
 - 20230322-143200
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-143200].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a48807701a694747e138f5d3243dffa81b475d3e5f722b6c11875150a4a30910].
$ rm -rf /tmp/tmp.aoGbYjJW2X
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322142040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322142040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322142040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:74023482e8ab28f094136185f6e73e9298dab5a553253b4246034422c2c69a28].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322142040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322142040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322142040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:49e952a4b51b22be7ec252b1e7ef7c5c8640a795611e72accab17c82d02e26ed].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2754130.
Stopping expansion service pid: 2754131.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 50s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1432

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1432/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206"
      }
    ]
  },
  "name": "go-testxlang_partition-144",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/22 09:18:12 Submitted job: 2023-03-22_02_18_12-13410272373313655545
2023/03/22 09:18:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-22_02_18_12-13410272373313655545?project=apache-beam-testing
2023/03/22 09:18:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-22_02_18_12-13410272373313655545
2023/03/22 09:18:12 Job state: JOB_STATE_PENDING ...
2023/03/22 09:18:42 Job still running ...
2023/03/22 09:19:13 Job still running ...
2023/03/22 09:19:43 Job still running ...
2023/03/22 09:20:13 Job still running ...
2023/03/22 09:20:43 Job still running ...
2023/03/22 09:21:13 Job still running ...
2023/03/22 09:21:43 Job still running ...
2023/03/22 09:22:13 Job still running ...
2023/03/22 09:22:43 Job still running ...
2023/03/22 09:23:14 Job still running ...
2023/03/22 09:23:44 Job still running ...
2023/03/22 09:24:14 Job still running ...
2023/03/22 09:24:44 Job still running ...
2023/03/22 09:25:14 Job still running ...
2023/03/22 09:25:44 Job still running ...
2023/03/22 09:26:14 Job still running ...
2023/03/22 09:26:44 Job still running ...
2023/03/22 09:27:14 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-22_02_18_12-13410272373313655545 failed
--- FAIL: TestXLang_Partition (581.76s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3303.448s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679473964608733324
--- FAIL: TestBigQueryIO_BasicWriteRead (4.88s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34201 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RAJqPZdVvs" is_bounded:BOUNDED windowing_strategy_id:"w0@RAJqPZdVvs"}} windowing_strategies:{key:"w0@RAJqPZdVvs" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RAJqPZdVvs" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RAJqPZdVvs" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RAJqPZdVvs" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679473964608733324\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RAJqPZdVvs"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34201 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RAJqPZdVvs" is_bounded:BOUNDED windowing_strategy_id:"w0@RAJqPZdVvs"}} windowing_strategies:{key:"w0@RAJqPZdVvs" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RAJqPZdVvs" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RAJqPZdVvs" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RAJqPZdVvs" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679473964608733324\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RAJqPZdVvs"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00057af00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00057af00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003f0fe0?, 0xc0000b9680?}, {0x113b23e, 0x39}, {0xc0001560c0?, 0xa9ea20?, 0x1?}, {0xc00041afc0, 0xf}, 0xc00053bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003f0f80?, 0xc0000b9680?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc00053bea8, 0x2, 0x7fd7cd7416b0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00041afc0, 0xf}, {0xc00004c5a0, 0x52}, {0xebcb60, 0xc0005462d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c89c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c89c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.918s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:495f523007cfc9686698b6cb04510bc56abcea15e00991cfa992e167118eff10
Deleted: sha256:10e74d2564fa300211f32e4dea357892552b8098e842bab71eb343d4100edc71
Deleted: sha256:64bfbd665f81a764ee9ab6f8118c11b5a279e9f44d7be8d04fd29ffe0492cae8
Deleted: sha256:337bc2a42d2eaf754b5fefe604542c258fdcb8340af17145f839637b8886eec7
Deleted: sha256:f4d16e1859604856b421570e534cc22412d055b832aedf1f637ac380ae34b4ba
Deleted: sha256:c1b195a6f0545b2406be7b9163430f14f616ab7c40151a30cbb98d60a8244a96
Deleted: sha256:739c06eb257a8fbd65b2c96bfe41df7318235fd61bb833da8f77b4883bdef5ed
Deleted: sha256:c677df1d96c22a5057dd700c3b2b2efb2e182e560d3e9532ff94349c95b4b5bf
Deleted: sha256:fabc8fce104d44721429e2139469b7b2c145f7b3041491bb8f6491f5a0ebe2e5
Deleted: sha256:38614fe7299954d78a94b47f740d2371f1d2008adc7e96363c3a7f6a83c2e2d9
Deleted: sha256:2be7b162bf1d25203ddaef47b8ca60119afac4a87587519a57c2a447cbc1131f
Deleted: sha256:c8934c5174e9aae82d0474ac9d0d21c5fa87f8f7c73ea55851d38cc6cf41df6c
Deleted: sha256:34c932870b0353bdaa2c6295431e9e494640eee73895f45b1ad4b21c616c4b5b
Deleted: sha256:06293f574b00bff994bcab8e7fe5469d4ed6a5f799fcd08a56565d4762d610cb
Deleted: sha256:5cbf21309cb05c274cde2cd668513ce814a58bb638ae27997ce89c59c6f3a109
Deleted: sha256:aadbc13fb0cb8e3d439a9d035b6f586df58afe5385cc3337e456900b16681849
Deleted: sha256:1dd28147e3d4412c4c4aae38430f10e1847cfe35f45cedd0ef21842d813f8228
Deleted: sha256:a2054be7c2229f565cd0e34f907fc2291939aed4d0759c5866c090195a4cc21f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:495f523007cfc9686698b6cb04510bc56abcea15e00991cfa992e167118eff10
  Associated tags:
 - 20230322-083206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-083206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:495f523007cfc9686698b6cb04510bc56abcea15e00991cfa992e167118eff10].
$ rm -rf /tmp/tmp.Sa5CUuBQcF
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322082042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322082042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322082042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b923ea122451ea628109a6045131e2201a838b234ffb006985cdb12472abee8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322082042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322082042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322082042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6a348cdd4fb1a1a64820df02580f635dd2d0115d62467fc2f6fb3ff970822f8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2494189.
Stopping expansion service pid: 2494190.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 28s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1431

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1431/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322022037",
            "environmentId": "vsiVAXmGywbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206"
      }
    ]
  },
  "name": "go-testxlang_partition-136",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/22 03:17:08 Submitted job: 2023-03-21_20_17_08-17922775779799528637
2023/03/22 03:17:08 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-21_20_17_08-17922775779799528637?project=apache-beam-testing
2023/03/22 03:17:08 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-21_20_17_08-17922775779799528637
2023/03/22 03:17:09 Job state: JOB_STATE_PENDING ...
2023/03/22 03:17:39 Job still running ...
2023/03/22 03:18:09 Job still running ...
2023/03/22 03:18:39 Job still running ...
2023/03/22 03:19:09 Job still running ...
2023/03/22 03:19:39 Job still running ...
2023/03/22 03:20:09 Job still running ...
2023/03/22 03:20:39 Job still running ...
2023/03/22 03:21:09 Job still running ...
2023/03/22 03:21:39 Job still running ...
2023/03/22 03:22:09 Job still running ...
2023/03/22 03:22:39 Job still running ...
2023/03/22 03:23:09 Job still running ...
2023/03/22 03:23:39 Job still running ...
2023/03/22 03:24:09 Job still running ...
2023/03/22 03:24:39 Job still running ...
2023/03/22 03:25:09 Job still running ...
2023/03/22 03:25:39 Job still running ...
2023/03/22 03:26:09 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-21_20_17_08-17922775779799528637 failed
--- FAIL: TestXLang_Partition (580.61s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.751s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679452361387659886
--- FAIL: TestBigQueryIO_BasicWriteRead (4.70s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40253 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rjKQFYphaa" is_bounded:BOUNDED windowing_strategy_id:"w0@rjKQFYphaa"}} windowing_strategies:{key:"w0@rjKQFYphaa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rjKQFYphaa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rjKQFYphaa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rjKQFYphaa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679452361387659886\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rjKQFYphaa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40253 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rjKQFYphaa" is_bounded:BOUNDED windowing_strategy_id:"w0@rjKQFYphaa"}} windowing_strategies:{key:"w0@rjKQFYphaa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rjKQFYphaa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rjKQFYphaa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rjKQFYphaa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679452361387659886\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rjKQFYphaa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3081)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2122)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000547d80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000547d80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7120?, 0xc0000bc280?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000412f00, 0xf}, 0xc000199d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a70a0?, 0xc0000bc280?}, {0xc000652360, 0x52}, {0x1?}, {0xc000199ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000412f00, 0xf}, {0xc000652360, 0x52}, {0xebcb60, 0xc000526188})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00042f6c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00042f6c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.734s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9868f90968a36886411fbfe6b5c40f0d2e1f5bce7f5afebe7e6cc4811f9f81fd
Deleted: sha256:d879f062b58713fcd1de9492cd9f1251341f93f3f59bb3c4123d4a3dbeb6d79a
Deleted: sha256:58aa57106f1f874647e927bd3b0db4f0bd46dbadbab5c88b5c38d5514ba36043
Deleted: sha256:3ded8cc5612a378b4459f9bb62ebd968ceb6e9531bb8a95c9704880604ebdb62
Deleted: sha256:5edede592fa65551015231bdbd8d0a95209c306d263ea98ae737646476a0ac9f
Deleted: sha256:fbf737ae760e47f4d5d3e8b70b0055984c3a255eb356e828f9346f418cbbd8e2
Deleted: sha256:2b4085a4f1645c7a4bb97b75f03ebb1aca5abd1e0d8222f8acb578acfbc52707
Deleted: sha256:87c960f922b787bb46ddb993ad393597c0957faac5fea6537483cecb53a8981e
Deleted: sha256:cafd019e86957a16859e60be9a6b082c063bf4f27b549279baa97fd4f83f35a4
Deleted: sha256:5900791d6867250db4d63f60b29d981e4d8a1af4de7654e5fcc0a97cfd5b03a7
Deleted: sha256:c249a2cd84af321804154e9d1ec233372e367a7bfdd127a5422e9ce914ab4ced
Deleted: sha256:51f305ea7f69f1c146e32c47bd6d3b50cb6fb64a67b863510544829d83fe5533
Deleted: sha256:7b1c810499831f0fb167d93949120e3c7fefb5ebc46ff9634439732cf550c063
Deleted: sha256:0d9c5f77ef8161409635f59f31137c629b36b9dcdc29ea389608d3c6bd8ec5ae
Deleted: sha256:d0274e5fa9ef7963c26b74c1cfcc12ccd5bce422fcffb607e24b0fe808313da7
Deleted: sha256:826db8b96113e820137bcaa44fa64677893f26400f0d3cfe1353d95976e2f826
Deleted: sha256:07c8f0ad5cce6940de479e0e3727134cd2801d079c12805fa775701230be5fd6
Deleted: sha256:f9d0360dda5c5d8f7ef70d4ca95a0c4992a9a269b0bc636c6b72e2bb4fd30ddf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9868f90968a36886411fbfe6b5c40f0d2e1f5bce7f5afebe7e6cc4811f9f81fd
  Associated tags:
 - 20230322-023206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230322-023206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9868f90968a36886411fbfe6b5c40f0d2e1f5bce7f5afebe7e6cc4811f9f81fd].
$ rm -rf /tmp/tmp.K4yXTmrq4y
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322022037
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322022037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230322022037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7fa3830d3831da2c6a6c89a5fdb0e0b2fd997cb62b72b34a21bb0e08a92d2c7c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322022037
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322022037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230322022037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6eab1fa7475871e39203f63f806969037d84d574a1a1a83fabc3b648dec07ef8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2139226.
Stopping expansion service pid: 2139227.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 27s
232 actionable tasks: 167 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1430

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1430/display/redirect?page=changes>

Changes:

[noreply] Raise the Runtime error when DoFn.process uses both yield and return


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321202044",
            "environmentId": "sZgUEPyVTObeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-203208",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-203208"
      }
    ]
  },
  "name": "go-testxlang_partition-883",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/21 21:17:52 Submitted job: 2023-03-21_14_17_52-8320782072949220752
2023/03/21 21:17:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-21_14_17_52-8320782072949220752?project=apache-beam-testing
2023/03/21 21:17:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-21_14_17_52-8320782072949220752
2023/03/21 21:17:52 Job state: JOB_STATE_PENDING ...
2023/03/21 21:18:22 Job still running ...
2023/03/21 21:18:52 Job still running ...
2023/03/21 21:19:22 Job still running ...
2023/03/21 21:19:52 Job still running ...
2023/03/21 21:20:22 Job still running ...
2023/03/21 21:20:52 Job still running ...
2023/03/21 21:21:22 Job still running ...
2023/03/21 21:21:52 Job still running ...
2023/03/21 21:22:23 Job still running ...
2023/03/21 21:22:53 Job still running ...
2023/03/21 21:23:23 Job still running ...
2023/03/21 21:23:53 Job still running ...
2023/03/21 21:24:23 Job still running ...
2023/03/21 21:24:53 Job still running ...
2023/03/21 21:25:23 Job still running ...
2023/03/21 21:25:53 Job still running ...
2023/03/21 21:26:23 Job still running ...
2023/03/21 21:26:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-21_14_17_52-8320782072949220752 failed
--- FAIL: TestXLang_Partition (581.67s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3280.393s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679430766419700821
--- FAIL: TestBigQueryIO_BasicWriteRead (4.77s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45321 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aQuPfgvliM" is_bounded:BOUNDED windowing_strategy_id:"w0@aQuPfgvliM"}} windowing_strategies:{key:"w0@aQuPfgvliM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aQuPfgvliM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aQuPfgvliM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aQuPfgvliM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679430766419700821\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aQuPfgvliM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45321 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aQuPfgvliM" is_bounded:BOUNDED windowing_strategy_id:"w0@aQuPfgvliM"}} windowing_strategies:{key:"w0@aQuPfgvliM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aQuPfgvliM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aQuPfgvliM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aQuPfgvliM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679430766419700821\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aQuPfgvliM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00029ac80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00029ac80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003faba0?, 0xc0000cb720?}, {0x113b23e, 0x39}, {0xc00015c0c0?, 0xa9ea20?, 0x1?}, {0xc0003f8c10, 0xf}, 0xc0000f3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0003fab40?, 0xc0000cb720?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc0000f3ea8, 0x2, 0x7f6ca47f0c10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f8c10, 0xf}, {0xc00004c4e0, 0x52}, {0xebcb60, 0xc0003f9f20})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001ad520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001ad520, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.809s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.040s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:04f41e79944af9e527e443ff70ace02bb07c490b414089e9bc3b52d6ab2349b2
  Associated tags:
 - 20230321-203208
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-203208
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-203208].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:04f41e79944af9e527e443ff70ace02bb07c490b414089e9bc3b52d6ab2349b2].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8d047289b8d744c44b7dfbf9a8bd4e0eb4fe72839d02765e306a5895bc516f5b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8d047289b8d744c44b7dfbf9a8bd4e0eb4fe72839d02765e306a5895bc516f5b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8d047289b8d744c44b7dfbf9a8bd4e0eb4fe72839d02765e306a5895bc516f5b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8d047289b8d744c44b7dfbf9a8bd4e0eb4fe72839d02765e306a5895bc516f5b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef5383de78328855cee5f38384bdfc5797f05c237c917f8fc13d2a9dba1bb2ce]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef5383de78328855cee5f38384bdfc5797f05c237c917f8fc13d2a9dba1bb2ce])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef5383de78328855cee5f38384bdfc5797f05c237c917f8fc13d2a9dba1bb2ce
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef5383de78328855cee5f38384bdfc5797f05c237c917f8fc13d2a9dba1bb2ce].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 5s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1429

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1429/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321142039",
            "environmentId": "wIvstQNWBLbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202"
      }
    ]
  },
  "name": "go-testxlang_partition-847",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/21 15:18:12 Submitted job: 2023-03-21_08_18_12-263203233574838875
2023/03/21 15:18:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-21_08_18_12-263203233574838875?project=apache-beam-testing
2023/03/21 15:18:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-21_08_18_12-263203233574838875
2023/03/21 15:18:12 Job state: JOB_STATE_PENDING ...
2023/03/21 15:18:43 Job still running ...
2023/03/21 15:19:13 Job still running ...
2023/03/21 15:19:43 Job still running ...
2023/03/21 15:20:13 Job still running ...
2023/03/21 15:20:43 Job still running ...
2023/03/21 15:21:13 Job still running ...
2023/03/21 15:21:43 Job still running ...
2023/03/21 15:22:13 Job still running ...
2023/03/21 15:22:43 Job still running ...
2023/03/21 15:23:13 Job still running ...
2023/03/21 15:23:43 Job still running ...
2023/03/21 15:24:13 Job still running ...
2023/03/21 15:24:43 Job still running ...
2023/03/21 15:25:13 Job still running ...
2023/03/21 15:25:43 Job still running ...
2023/03/21 15:26:14 Job still running ...
2023/03/21 15:26:44 Job still running ...
2023/03/21 15:27:14 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-21_08_18_12-263203233574838875 failed
--- FAIL: TestXLang_Partition (581.97s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3309.529s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679409158023238958
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46475 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@TjgbTkfCNy" is_bounded:BOUNDED windowing_strategy_id:"w0@TjgbTkfCNy"}} windowing_strategies:{key:"w0@TjgbTkfCNy" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@TjgbTkfCNy" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@TjgbTkfCNy" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@TjgbTkfCNy" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679409158023238958\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"TjgbTkfCNy"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46475 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@TjgbTkfCNy" is_bounded:BOUNDED windowing_strategy_id:"w0@TjgbTkfCNy"}} windowing_strategies:{key:"w0@TjgbTkfCNy" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@TjgbTkfCNy" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@TjgbTkfCNy" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@TjgbTkfCNy" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679409158023238958\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"TjgbTkfCNy"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0006943c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0006943c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e900?, 0xc0000bda40?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000124a60, 0xf}, 0xc0004d5d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e8a0?, 0xc0000bda40?}, {0xc000136300, 0x52}, {0x1?}, {0xc0004d5ea8, 0x2, 0x7ff230db0bb8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000124a60, 0xf}, {0xc000136300, 0x52}, {0xebcb60, 0xc000125d70})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102b60, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.471s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9c816214e69e7a0ff3bf23ca8055c6f2708ada8a563490ee59de3e935263f4b3
Deleted: sha256:9407a25e7c4bee1ccc1575e840d0b504fe49306a475b5cd352494c168623a8b7
Deleted: sha256:75a50aa9f1cd9de27313a3c20a3b188ed602b082c64bf51442137bd896f93be6
Deleted: sha256:40f01f77c56baeae666e801a0ea873a57824a0f0a4e0f9f96fa974dc0867292a
Deleted: sha256:0cc4dfc41d7b9144cee2a6bc88ada89d339eb152b7a8ab55d76617aebd7c717e
Deleted: sha256:dcdb9661dc0e1909c1b51db3abeb31ecef9a74319df049c3323a99b89e61728f
Deleted: sha256:5d8adc2c5669584f43bde30cd25638196404015ccb8eb057eefb12b269ece45b
Deleted: sha256:150b43c4eebf7b46159f6343fb6572e29e3ebb9c6c8af949b39fa85cad8b9d06
Deleted: sha256:e2342635aebd3bcb8a3bf952cd628f9cff7430c0375f234ce0f76a175bb7bbd5
Deleted: sha256:30b19b820b1218c25a6ff5fbfef561c959a8d5664d6de1d075faa21f41cd5360
Deleted: sha256:4426e91090c0d065c5dc3ee4766fb1b7e7a481956d0c91df633af49dca064d1e
Deleted: sha256:3f7a7254559651487a4f7253ce1c5433f5a36cf91beb700ad2b8d0f507337722
Deleted: sha256:95c759648881a88699d94022494735b6282f6f74cf06e0b9400b372ac8d35e0e
Deleted: sha256:48ecebc8a2bd0ec5c974d807c225e2ea211befff8aaeda2c17498c883a2794a7
Deleted: sha256:9f8f82d5c2f568fb38dad4c2cb575a3c25c75a20c2eeef55e89ab7ec4e3fb295
Deleted: sha256:a07ec0837729c690f4a4cda2e65b48eb36c3aeacb86491cb8c449bdbf9a7a9dc
Deleted: sha256:c768cafe374bddfadab29dc58244a36ddad783a3b709fb50a41dc30db641f1d9
Deleted: sha256:64ca498a423ebd68ee31494703e46a5c2de0f0ec45ca44cbf6e1b005a78fada2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9c816214e69e7a0ff3bf23ca8055c6f2708ada8a563490ee59de3e935263f4b3
  Associated tags:
 - 20230321-143202
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-143202].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9c816214e69e7a0ff3bf23ca8055c6f2708ada8a563490ee59de3e935263f4b3].
$ rm -rf /tmp/tmp.TcZxv6Mmpn
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321142039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321142039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321142039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d6f74dbcb28add5eab8cf6e52f788f4f06ed6d696e0a7c61eecc527e0462c48].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321142039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321142039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321142039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b5c03df909f7f98e727ac28e3cbbddf24c1963fde6b0588f41fd39acdce992e6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1467949.
Stopping expansion service pid: 1467950.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 30s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1428

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1428/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-083208",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321082044",
            "environmentId": "UKfByKJximbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-083208"
      }
    ]
  },
  "name": "go-testxlang_partition-958",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/21 09:17:45 Submitted job: 2023-03-21_02_17_44-737946907116949351
2023/03/21 09:17:45 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-21_02_17_44-737946907116949351?project=apache-beam-testing
2023/03/21 09:17:45 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-21_02_17_44-737946907116949351
2023/03/21 09:17:45 Job state: JOB_STATE_PENDING ...
2023/03/21 09:18:15 Job still running ...
2023/03/21 09:18:45 Job still running ...
2023/03/21 09:19:15 Job still running ...
2023/03/21 09:19:45 Job still running ...
2023/03/21 09:20:15 Job still running ...
2023/03/21 09:20:45 Job still running ...
2023/03/21 09:21:15 Job still running ...
2023/03/21 09:21:45 Job still running ...
2023/03/21 09:22:15 Job still running ...
2023/03/21 09:22:45 Job still running ...
2023/03/21 09:23:15 Job still running ...
2023/03/21 09:23:45 Job still running ...
2023/03/21 09:24:15 Job still running ...
2023/03/21 09:24:45 Job still running ...
2023/03/21 09:25:15 Job still running ...
2023/03/21 09:25:45 Job still running ...
2023/03/21 09:26:15 Job still running ...
2023/03/21 09:26:45 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-21_02_17_44-737946907116949351 failed
--- FAIL: TestXLang_Partition (580.99s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3271.712s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679387567545558239
--- FAIL: TestBigQueryIO_BasicWriteRead (4.37s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46255 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZjXsSzbeiP" is_bounded:BOUNDED windowing_strategy_id:"w0@ZjXsSzbeiP"}} windowing_strategies:{key:"w0@ZjXsSzbeiP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZjXsSzbeiP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZjXsSzbeiP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZjXsSzbeiP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679387567545558239\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZjXsSzbeiP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46255 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZjXsSzbeiP" is_bounded:BOUNDED windowing_strategy_id:"w0@ZjXsSzbeiP"}} windowing_strategies:{key:"w0@ZjXsSzbeiP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZjXsSzbeiP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZjXsSzbeiP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZjXsSzbeiP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679387567545558239\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZjXsSzbeiP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 14 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0004265c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0004265c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010f060?, 0xc000493770?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9ea20?, 0x1?}, {0xc000130dc0, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010f000?, 0xc000493770?}, {0xc0001543c0, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f709ca5ca08?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000130dc0, 0xf}, {0xc0001543c0, 0x52}, {0xebcb60, 0xc0003fc0d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103860, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.401s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:203e900a33e7e588aa01d511671a940aa2b79cb3bd070c77adc6451b99e4d574
  Associated tags:
 - 20230321-083208
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-083208
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-083208].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:203e900a33e7e588aa01d511671a940aa2b79cb3bd070c77adc6451b99e4d574].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2ee8512f7c04d8983b1cd6df46d81c2b596d5bc828371e207fdd7e621e79a389]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2ee8512f7c04d8983b1cd6df46d81c2b596d5bc828371e207fdd7e621e79a389])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2ee8512f7c04d8983b1cd6df46d81c2b596d5bc828371e207fdd7e621e79a389
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2ee8512f7c04d8983b1cd6df46d81c2b596d5bc828371e207fdd7e621e79a389].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9887f63bdb9aed61ceec19481cd2007ff35b47b580c19a4b4dabd10d32918f3c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9887f63bdb9aed61ceec19481cd2007ff35b47b580c19a4b4dabd10d32918f3c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9887f63bdb9aed61ceec19481cd2007ff35b47b580c19a4b4dabd10d32918f3c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9887f63bdb9aed61ceec19481cd2007ff35b47b580c19a4b4dabd10d32918f3c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 1s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2enrar2nkje46

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1427

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1427/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-023213",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321022042",
            "environmentId": "GjZbqHxCXVbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-023213"
      }
    ]
  },
  "name": "go-testxlang_partition-872",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/21 03:16:44 Submitted job: 2023-03-20_20_16_44-18109665441333962277
2023/03/21 03:16:44 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-20_20_16_44-18109665441333962277?project=apache-beam-testing
2023/03/21 03:16:44 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-20_20_16_44-18109665441333962277
2023/03/21 03:16:44 Job state: JOB_STATE_PENDING ...
2023/03/21 03:17:15 Job still running ...
2023/03/21 03:17:45 Job still running ...
2023/03/21 03:18:15 Job still running ...
2023/03/21 03:18:45 Job still running ...
2023/03/21 03:19:15 Job still running ...
2023/03/21 03:19:45 Job still running ...
2023/03/21 03:20:15 Job still running ...
2023/03/21 03:20:45 Job still running ...
2023/03/21 03:21:15 Job still running ...
2023/03/21 03:21:45 Job still running ...
2023/03/21 03:22:15 Job still running ...
2023/03/21 03:22:45 Job still running ...
2023/03/21 03:23:15 Job still running ...
2023/03/21 03:23:45 Job still running ...
2023/03/21 03:24:15 Job still running ...
2023/03/21 03:24:46 Job still running ...
2023/03/21 03:25:16 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-20_20_16_44-18109665441333962277 failed
--- FAIL: TestXLang_Partition (551.17s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3179.398s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679365975415405408
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36371 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xguQBpCyOD" is_bounded:BOUNDED windowing_strategy_id:"w0@xguQBpCyOD"}} windowing_strategies:{key:"w0@xguQBpCyOD" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xguQBpCyOD" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xguQBpCyOD" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xguQBpCyOD" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679365975415405408\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xguQBpCyOD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36371 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xguQBpCyOD" is_bounded:BOUNDED windowing_strategy_id:"w0@xguQBpCyOD"}} windowing_strategies:{key:"w0@xguQBpCyOD" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xguQBpCyOD" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xguQBpCyOD" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xguQBpCyOD" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679365975415405408\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xguQBpCyOD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 6 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0000bcdc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0000bcdc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000534960?, 0xc000115b30?}, {0x113b23e, 0x39}, {0xc00015c0c0?, 0xa9ea20?, 0x1?}, {0xc000042d60, 0xf}, 0xc0000fdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000534900?, 0xc000115b30?}, {0xc0006923c0, 0x52}, {0x1?}, {0xc0000fdea8, 0x2, 0x7ff26e5a8888?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d60, 0xf}, {0xc0006923c0, 0x52}, {0xebcb60, 0xc0001341d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006429c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006429c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.287s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.031s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a13007227f0b5e67bdfa12ffc6143db08cff784b9ee7991e28160b81a78fbc7e
  Associated tags:
 - 20230321-023213
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-023213
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230321-023213].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a13007227f0b5e67bdfa12ffc6143db08cff784b9ee7991e28160b81a78fbc7e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:807472023296b6351e2436d1fee9fd16ad9765ca2530a95b66255a3c104a7416]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230321022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:807472023296b6351e2436d1fee9fd16ad9765ca2530a95b66255a3c104a7416])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:807472023296b6351e2436d1fee9fd16ad9765ca2530a95b66255a3c104a7416
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:807472023296b6351e2436d1fee9fd16ad9765ca2530a95b66255a3c104a7416].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:79d8f7209150b5ab245bd624573392d9770182466fff1dbec50bf2e816e8bfa9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230321022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:79d8f7209150b5ab245bd624573392d9770182466fff1dbec50bf2e816e8bfa9])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:79d8f7209150b5ab245bd624573392d9770182466fff1dbec50bf2e816e8bfa9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:79d8f7209150b5ab245bd624573392d9770182466fff1dbec50bf2e816e8bfa9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 29s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2ep3kqxkwoj4w

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1426

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1426/display/redirect?page=changes>

Changes:

[noreply] Add one example to learn beam by doing (#25719)


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320202040",
            "environmentId": "CvYMpAZcSGbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216"
      }
    ]
  },
  "name": "go-testxlang_partition-519",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/20 21:19:52 Submitted job: 2023-03-20_14_19_51-261086447300534468
2023/03/20 21:19:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-20_14_19_51-261086447300534468?project=apache-beam-testing
2023/03/20 21:19:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-20_14_19_51-261086447300534468
2023/03/20 21:19:52 Job state: JOB_STATE_PENDING ...
2023/03/20 21:20:22 Job still running ...
2023/03/20 21:20:52 Job still running ...
2023/03/20 21:21:22 Job still running ...
2023/03/20 21:21:52 Job still running ...
2023/03/20 21:22:22 Job still running ...
2023/03/20 21:22:52 Job still running ...
2023/03/20 21:23:22 Job still running ...
2023/03/20 21:23:52 Job still running ...
2023/03/20 21:24:22 Job still running ...
2023/03/20 21:24:52 Job still running ...
2023/03/20 21:25:22 Job still running ...
2023/03/20 21:25:52 Job still running ...
2023/03/20 21:26:22 Job still running ...
2023/03/20 21:26:52 Job still running ...
2023/03/20 21:27:23 Job still running ...
2023/03/20 21:27:53 Job still running ...
2023/03/20 21:28:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-20_14_19_51-261086447300534468 failed
--- FAIL: TestXLang_Partition (550.65s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3363.920s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679344372543198511
--- FAIL: TestBigQueryIO_BasicWriteRead (4.49s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39503 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oBcagqZeJm" is_bounded:BOUNDED windowing_strategy_id:"w0@oBcagqZeJm"}} windowing_strategies:{key:"w0@oBcagqZeJm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oBcagqZeJm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oBcagqZeJm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oBcagqZeJm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679344372543198511\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oBcagqZeJm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39503 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oBcagqZeJm" is_bounded:BOUNDED windowing_strategy_id:"w0@oBcagqZeJm"}} windowing_strategies:{key:"w0@oBcagqZeJm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oBcagqZeJm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oBcagqZeJm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oBcagqZeJm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679344372543198511\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oBcagqZeJm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 55 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000032a00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000032a00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040c140?, 0xc000138230?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000588b80, 0xf}, 0xc000453d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040c0a0?, 0xc000138230?}, {0xc00010e7e0, 0x52}, {0x1?}, {0xc000453ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000588b80, 0xf}, {0xc00010e7e0, 0x52}, {0xebcb60, 0xc000402178})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000422d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000422d00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.524s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:482163b4316e304468ed780e9d141fa9cdc2f16693df0fc895f12918f607f4be
Deleted: sha256:a6265b158a0587be1f23378e2c8e7ee7065905775b6f82a3a29b891024b1897c
Deleted: sha256:a5c365c663ccfea2600753d49e1687ec673040168a8b1d3fef0cbb4f0e83e487
Deleted: sha256:31c767c4f8e1bd4cef1deed0c0eee11390a256edb072d9104123b23fd62cdeb6
Deleted: sha256:21e1ffbf2ddf1b5946ea84bf5fcd2d09b7f4d32a91d5eeb9017a066cf6ca813f
Deleted: sha256:2c163ac5663db91a3ef9a55eeea04281869b8cad5434f05b51fcfe5c24f29e9a
Deleted: sha256:fcc42916baf8f3a81949999f8f2333f8728b8f8090253f3a8a5f58a29d0342be
Deleted: sha256:fd7d12e7c417ae02d350e093e7110665467e1b2ef11dc83efc44b5de4aae3474
Deleted: sha256:d5f0b2939214dd171e5c92e2a1d79309f9536d711b5b0111322d287779fe92bc
Deleted: sha256:ec957feaacef25c5c09b35fc0a5102be2a23cefe81769c89ebab74b6509755d6
Deleted: sha256:aeca08d55cc79eb3ff6bdd81b921ee26f62d8b7a7f040b745b0a9c844d753f85
Deleted: sha256:9e2294676779222925f7852bdc9bbecd7d72c2d546406abf2f165463db52f1f1
Deleted: sha256:21b9d01c7bc629d73db30de3e2bb7f22cf000e49f5cffd6ad91b100fe2eb12bd
Deleted: sha256:1ceffd30fb570a0ed0c1716206e4aca2df909b8a1b2d82158293a67bebc61e29
Deleted: sha256:26ed01a359e90e8bca9e68ac4151be29930878de992fbe55c9e43a9bbb9e3387
Deleted: sha256:97bd6a44bc81d65e7ffc9b3f22d54f540f7fd97142d7f4586902dce76886b000
Deleted: sha256:a93401a4e9936b70919fa979631a82a50b00376a6bc3e660ea62e517d0c42e36
Deleted: sha256:7f7c792c17a0f4a3ef04fdab25f0a1705490455ed7ad5f81387c13a6fa78f51f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:482163b4316e304468ed780e9d141fa9cdc2f16693df0fc895f12918f607f4be
  Associated tags:
 - 20230320-203216
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-203216].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:482163b4316e304468ed780e9d141fa9cdc2f16693df0fc895f12918f607f4be].
$ rm -rf /tmp/tmp.Ms1K3gx8gi
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b4ac483de4f05f1e7eb0e98553629cd220d3ecc089cd182de8a7434a6c2bbb54].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ab7cc5aaec0d399c8fe0a00c286e4e2057a9d869b11160b8614902dcd8d6d775].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 681798.
Stopping expansion service pid: 681799.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 44s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1425

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1425/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
}
2023/03/20 15:18:04 Submitted job: 2023-03-20_08_18_04-14690344538293513641
2023/03/20 15:18:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-20_08_18_04-14690344538293513641?project=apache-beam-testing
2023/03/20 15:18:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-20_08_18_04-14690344538293513641
2023/03/20 15:18:04 Job state: JOB_STATE_PENDING ...
2023/03/20 15:18:34 Job still running ...
2023/03/20 15:19:04 Job still running ...
2023/03/20 15:19:35 Job still running ...
2023/03/20 15:20:05 Job still running ...
2023/03/20 15:20:35 Job still running ...
2023/03/20 15:21:05 Job still running ...
2023/03/20 15:21:35 Job still running ...
2023/03/20 15:22:05 Job still running ...
2023/03/20 15:22:35 Job still running ...
2023/03/20 15:23:05 Job still running ...
2023/03/20 15:23:35 Job still running ...
2023/03/20 15:24:05 Job still running ...
2023/03/20 15:24:35 Job still running ...
2023/03/20 15:25:05 Job still running ...
2023/03/20 15:25:35 Job still running ...
2023/03/20 15:26:05 Job still running ...
2023/03/20 15:26:35 Job still running ...
2023/03/20 15:27:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-20_08_18_04-14690344538293513641 failed
--- FAIL: TestXLang_Partition (581.01s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3271.779s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679322787486179406
--- FAIL: TestBigQueryIO_BasicWriteRead (4.51s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41449 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FrOyiUwVKF" is_bounded:BOUNDED windowing_strategy_id:"w0@FrOyiUwVKF"}} windowing_strategies:{key:"w0@FrOyiUwVKF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FrOyiUwVKF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FrOyiUwVKF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FrOyiUwVKF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679322787486179406\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FrOyiUwVKF"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41449 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FrOyiUwVKF" is_bounded:BOUNDED windowing_strategy_id:"w0@FrOyiUwVKF"}} windowing_strategies:{key:"w0@FrOyiUwVKF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FrOyiUwVKF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FrOyiUwVKF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FrOyiUwVKF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679322787486179406\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FrOyiUwVKF"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0004eec00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0004eec00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168fc0?, 0xc000428050?}, {0x113b23e, 0x39}, {0xc00015c0c0?, 0xa9e920?, 0x1?}, {0xc000042e20, 0xf}, 0xc0000d1d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168f60?, 0xc000428050?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc0000d1ea8, 0x2, 0x7f0c82bbc4d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042e20, 0xf}, {0xc00004c5a0, 0x52}, {0xebcb60, 0xc00041c1f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c8b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c8b60, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.547s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b1a12e85c270589b977ccce0293754bdfc6464802c350c0825a2f66f896c0dc9
Deleted: sha256:fe49d4cf0b034486125b1f9128b0735d9e8165b247302f54b67c5071d6e37399
Deleted: sha256:d21d66804b59ad6719173d825f0a2fcac41b668abce25f2cde8aef1a63632221
Deleted: sha256:8372f66531b1ebf4b145cde13b736da432b3a35c41d2bcb4d7916217033cfc39
Deleted: sha256:8f56e686343d2e3fa76892ef1ba925d87e7d0c13af49046b3c20ab8c322a6482
Deleted: sha256:d39d4ec97f78d41446d84b8cf702bffa83b20302c8317f90a1cc15d15f1da29e
Deleted: sha256:3fa3227a1a00ec1f272c7f4773b350ee70d6df032e77f0254fbc012d21c78e5a
Deleted: sha256:1aceb0f78d16aae78c393e743209003cfa184c4b0f1d36f4e08cb87acc5bcfc6
Deleted: sha256:a5f7e8b6c66fdbdf66df807d3fb9d538f7dc5ff605fd2f5c50a4bf2764694d9d
Deleted: sha256:ce3411976dc5a41d0b0828e21810f5ab24a1ee0e7683a36598e9268d2ad35228
Deleted: sha256:19e3945a9b788ed8852093ddb7e3a3b1c208e9509183c640e1217420a99e8d3e
Deleted: sha256:1d01db2573f593a88878b2216ab448f51411fe5761101fcdab77dd2e74d03057
Deleted: sha256:fef0e61ee5631084ee876e8d98ec9f41fb781516be37814f655cbf3864888b92
Deleted: sha256:e9aafcf346c25a652230803f746f523129f4ffe4245f2677ba3d60ead896a2f6
Deleted: sha256:486c68ae28fd68b04c839521372b89675fbebc2659113658f0675cee859b6fef
Deleted: sha256:801f6003919bf5fff2c9144e86b571492066ae0436daaf5f1f39982fe6b6da17
Deleted: sha256:8a4d41df5e3be9d90a70b9cf89d96fd094309114067ec052f17a8f8f26d621ca
Deleted: sha256:50b421d421fcc40cad39859e137c8ede2757c9359919b860dbe29b32f787c4aa
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-143230
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b1a12e85c270589b977ccce0293754bdfc6464802c350c0825a2f66f896c0dc9
  Associated tags:
 - 20230320-143230
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-143230
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-143230].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b1a12e85c270589b977ccce0293754bdfc6464802c350c0825a2f66f896c0dc9].
$ rm -rf /tmp/tmp.gV6pQyHNhr
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7b8c6a7459db3db7d63a3e1910ce5288c4e53007099acf3f8f93beadf37e2ac0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320142041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635
Deleted: sha256:47655d78254d06e989f5c77f4317e60b6ef5593084e4fca00334478dd9c420fa
Deleted: sha256:64272093299b0c61ff6b89590d1dbc38ee927935b515cc43e09d4161da8ac255
Deleted: sha256:d71af4fabf9439c186bae3ce898733eae148c43ff4f7253bd86a47befc3eacd0
Deleted: sha256:51fa6ad196d2a8c47c5a3f571d437c97e7262b9ff0e2dae1486414e6c736225b
Deleted: sha256:65a7f133d5fa557119b6c725a2e39412ac96f6e0053262197baf1f57cb2686d0
Deleted: sha256:b3a6f5db4121671233c6ecdcab5831ed467b89cc51273b98d9ca717c91a750a9
Deleted: sha256:04a3e7b596c0b775b6a68310220c8f92fbdb68440a0750fc28f6325a94b7e358
Deleted: sha256:8b7b795a509bd3ee8c799807bbe3c5ae124ee84031651e97850892c1ec12b18c
Deleted: sha256:8f8151908b55a0df7d61786124cce4d99bc39143d5d4ea4ea9f86a21c374f2bc
Deleted: sha256:4f36dc640aab98b9285cd82dac31857f77dc9fba526ba12578dbf8aaf7535b4d
Deleted: sha256:733e5ffcf93e830e56cb719211f0b1a6c688fde960b1c9ca15bb59cc33a30da4
Deleted: sha256:b7dc522195cb020e63fc860ee85472e7f38f8ba3f7a0d1213cf979ae067a2d85
Deleted: sha256:a1b1cb4958f2d739993e85d344eb880dcc017d01b03275ffda818d87bba4a575
Deleted: sha256:5f4c8b56061581e305862135fd5fea3acc50354e4373beecee7fd59de6c7740a
Deleted: sha256:85e4454e6ba4177e5e18798553ec2b2069c015a9bd0f69fedd28da3b5c010dd5
Deleted: sha256:9bf15819eac04c744eb4bd2f25bdd5c4be6a27de76dc53071ecdad11c1573655
Deleted: sha256:38555e75cdbea4e421d94e54ac4ae98b8533ead9d614730ddfac06acb579297e
Deleted: sha256:f086218ed50f14d95a8ed68a5ae5ebfbf1fcf35f2893d123b7967635edc3057e
Deleted: sha256:6ac3658124874bd31ed90e743d5577cb674cfc57dfdc5a4f8e83c0c679cccd7a
Deleted: sha256:5e0dbb417373e4bfa7c2fdd7542d3e7f22e1fb03fcffbf95218c1e8d7c1aa2c7
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cdec2e67c94f788fb5600f532e9919457054f1f2d95d50f7d1eeac29b5e44635].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 219914.
Stopping expansion service pid: 219915.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 37s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1424

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1424/display/redirect>

Changes:


------------------------------------------
[...truncated 566.79 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-083241",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320082041",
            "environmentId": "YnESDlRxnVbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-083241"
      }
    ]
  },
  "name": "go-testxlang_partition-666",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/20 09:17:14 Submitted job: 2023-03-20_02_17_13-2630302988131352497
2023/03/20 09:17:14 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-20_02_17_13-2630302988131352497?project=apache-beam-testing
2023/03/20 09:17:14 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-20_02_17_13-2630302988131352497
2023/03/20 09:17:14 Job state: JOB_STATE_PENDING ...
2023/03/20 09:17:44 Job still running ...
2023/03/20 09:18:14 Job still running ...
2023/03/20 09:18:44 Job still running ...
2023/03/20 09:19:14 Job still running ...
2023/03/20 09:19:44 Job still running ...
2023/03/20 09:20:14 Job still running ...
2023/03/20 09:20:44 Job still running ...
2023/03/20 09:21:14 Job still running ...
2023/03/20 09:21:44 Job still running ...
2023/03/20 09:22:14 Job still running ...
2023/03/20 09:22:44 Job still running ...
2023/03/20 09:23:15 Job still running ...
2023/03/20 09:23:45 Job still running ...
2023/03/20 09:24:15 Job still running ...
2023/03/20 09:24:45 Job still running ...
2023/03/20 09:25:15 Job still running ...
2023/03/20 09:25:45 Job still running ...
2023/03/20 09:26:15 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-20_02_17_13-2630302988131352497 failed
--- FAIL: TestXLang_Partition (581.01s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.081s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679301198508082471
--- FAIL: TestBigQueryIO_BasicWriteRead (4.50s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34445 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NycwNTzfiv" is_bounded:BOUNDED windowing_strategy_id:"w0@NycwNTzfiv"}} windowing_strategies:{key:"w0@NycwNTzfiv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NycwNTzfiv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NycwNTzfiv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NycwNTzfiv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679301198508082471\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NycwNTzfiv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34445 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NycwNTzfiv" is_bounded:BOUNDED windowing_strategy_id:"w0@NycwNTzfiv"}} windowing_strategies:{key:"w0@NycwNTzfiv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NycwNTzfiv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NycwNTzfiv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NycwNTzfiv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679301198508082471\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NycwNTzfiv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000155880})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000155880})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169100?, 0xc0000ce000?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc00001ac70, 0xf}, 0xc00019dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169080?, 0xc0000ce000?}, {0xc0001188a0, 0x52}, {0x1?}, {0xc00019dea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00001ac70, 0xf}, {0xc0001188a0, 0x52}, {0xebcb60, 0xc000402238})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c6820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c6820, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.533s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b92f3067043bb9b59059ffd541b24cab6b4eb23f06101236198b520def3f23ab
  Associated tags:
 - 20230320-083241
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-083241
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-083241].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b92f3067043bb9b59059ffd541b24cab6b4eb23f06101236198b520def3f23ab].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:947d4515bc88683e7a9676235b6080e7c4c325c6a528e22e97f4a21d7ad566a0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:947d4515bc88683e7a9676235b6080e7c4c325c6a528e22e97f4a21d7ad566a0])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:947d4515bc88683e7a9676235b6080e7c4c325c6a528e22e97f4a21d7ad566a0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:947d4515bc88683e7a9676235b6080e7c4c325c6a528e22e97f4a21d7ad566a0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6f7ca5e78488ed292c5036395537da1873625ef2d1df05a2c2463c9814f3e694]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6f7ca5e78488ed292c5036395537da1873625ef2d1df05a2c2463c9814f3e694])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6f7ca5e78488ed292c5036395537da1873625ef2d1df05a2c2463c9814f3e694
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6f7ca5e78488ed292c5036395537da1873625ef2d1df05a2c2463c9814f3e694].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 30s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1423

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1423/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320022031",
            "environmentId": "AjYPcxmhISbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-023148",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-023148"
      }
    ]
  },
  "name": "go-testxlang_partition-784",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/20 03:17:48 Submitted job: 2023-03-19_20_17_47-956202471016900361
2023/03/20 03:17:48 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-19_20_17_47-956202471016900361?project=apache-beam-testing
2023/03/20 03:17:48 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-19_20_17_47-956202471016900361
2023/03/20 03:17:48 Job state: JOB_STATE_PENDING ...
2023/03/20 03:18:18 Job still running ...
2023/03/20 03:18:48 Job still running ...
2023/03/20 03:19:18 Job still running ...
2023/03/20 03:19:48 Job still running ...
2023/03/20 03:20:18 Job still running ...
2023/03/20 03:20:48 Job still running ...
2023/03/20 03:21:18 Job still running ...
2023/03/20 03:21:48 Job still running ...
2023/03/20 03:22:18 Job still running ...
2023/03/20 03:22:48 Job still running ...
2023/03/20 03:23:18 Job still running ...
2023/03/20 03:23:48 Job still running ...
2023/03/20 03:24:18 Job still running ...
2023/03/20 03:24:48 Job still running ...
2023/03/20 03:25:18 Job still running ...
2023/03/20 03:25:48 Job still running ...
2023/03/20 03:26:18 Job still running ...
2023/03/20 03:26:49 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-19_20_17_47-956202471016900361 failed
--- FAIL: TestXLang_Partition (580.29s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3297.402s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679279544982747468
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38473 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mJLEJGxooC" is_bounded:BOUNDED windowing_strategy_id:"w0@mJLEJGxooC"}} windowing_strategies:{key:"w0@mJLEJGxooC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mJLEJGxooC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mJLEJGxooC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mJLEJGxooC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679279544982747468\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mJLEJGxooC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38473 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mJLEJGxooC" is_bounded:BOUNDED windowing_strategy_id:"w0@mJLEJGxooC"}} windowing_strategies:{key:"w0@mJLEJGxooC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mJLEJGxooC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mJLEJGxooC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mJLEJGxooC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679279544982747468\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mJLEJGxooC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000561100})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000561100})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040a8e0?, 0xc0000bc0f0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000043010, 0xf}, 0xc000033d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040a880?, 0xc0000bc0f0?}, {0xc00068e3c0, 0x52}, {0x1?}, {0xc000033ea8, 0x2, 0x7f121ddaadf8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043010, 0xf}, {0xc00068e3c0, 0x52}, {0xebcb60, 0xc00040c1f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0002ff860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0002ff860, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.437s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:64cec0bf83e40cb435bb1efa411e89745252d9fba6b17a8e30ce97104eab69a1
  Associated tags:
 - 20230320-023148
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-023148
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230320-023148].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:64cec0bf83e40cb435bb1efa411e89745252d9fba6b17a8e30ce97104eab69a1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320022031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cbc505dd874069b9dce00bac199716077e1a00939629b5e518d4c88c332dcea4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230320022031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cbc505dd874069b9dce00bac199716077e1a00939629b5e518d4c88c332dcea4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cbc505dd874069b9dce00bac199716077e1a00939629b5e518d4c88c332dcea4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cbc505dd874069b9dce00bac199716077e1a00939629b5e518d4c88c332dcea4].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320022031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:df7c10bbb18b465cca6cb72f17c9be7d66282b2d74fa6a7bb85bb34da7ad949b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230320022031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:df7c10bbb18b465cca6cb72f17c9be7d66282b2d74fa6a7bb85bb34da7ad949b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:df7c10bbb18b465cca6cb72f17c9be7d66282b2d74fa6a7bb85bb34da7ad949b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:df7c10bbb18b465cca6cb72f17c9be7d66282b2d74fa6a7bb85bb34da7ad949b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 12s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1422

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1422/display/redirect?page=changes>

Changes:

[noreply] add write options with create disposition for bigqueryio (#25352)


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319202041",
            "environmentId": "FDYxOljinpbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219"
      }
    ]
  },
  "name": "go-testxlang_partition-99",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/19 21:16:54 Submitted job: 2023-03-19_14_16_53-7946115521062652093
2023/03/19 21:16:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-19_14_16_53-7946115521062652093?project=apache-beam-testing
2023/03/19 21:16:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-19_14_16_53-7946115521062652093
2023/03/19 21:16:54 Job state: JOB_STATE_PENDING ...
2023/03/19 21:17:24 Job still running ...
2023/03/19 21:17:54 Job still running ...
2023/03/19 21:18:24 Job still running ...
2023/03/19 21:18:54 Job still running ...
2023/03/19 21:19:24 Job still running ...
2023/03/19 21:19:54 Job still running ...
2023/03/19 21:20:24 Job still running ...
2023/03/19 21:20:54 Job still running ...
2023/03/19 21:21:24 Job still running ...
2023/03/19 21:21:54 Job still running ...
2023/03/19 21:22:24 Job still running ...
2023/03/19 21:22:54 Job still running ...
2023/03/19 21:23:25 Job still running ...
2023/03/19 21:23:55 Job still running ...
2023/03/19 21:24:25 Job still running ...
2023/03/19 21:24:55 Job still running ...
2023/03/19 21:25:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-19_14_16_53-7946115521062652093 failed
--- FAIL: TestXLang_Partition (550.33s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3178.828s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679257982649823544
--- FAIL: TestBigQueryIO_BasicWriteRead (4.48s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36659 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nJmfrizehF" is_bounded:BOUNDED windowing_strategy_id:"w0@nJmfrizehF"}} windowing_strategies:{key:"w0@nJmfrizehF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nJmfrizehF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nJmfrizehF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nJmfrizehF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679257982649823544\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nJmfrizehF"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36659 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nJmfrizehF" is_bounded:BOUNDED windowing_strategy_id:"w0@nJmfrizehF"}} windowing_strategies:{key:"w0@nJmfrizehF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nJmfrizehF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nJmfrizehF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nJmfrizehF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679257982649823544\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nJmfrizehF"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0004fd100})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0004fd100})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7800?, 0xc0003f3770?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000684c10, 0xf}, 0xc0006b1d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a77a0?, 0xc0003f3770?}, {0xc00068c300, 0x52}, {0x1?}, {0xc0006b1ea8, 0x2, 0x7fa8046c8518?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000684c10, 0xf}, {0xc00068c300, 0x52}, {0xebcb60, 0xc000685f20})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.515s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a28571eb93e9ca321ad1b971632858d8fe490e383e2e0d53282ea0ecaf95c7a6
Deleted: sha256:752617f52904982d598a00d7f025cf7369cb4fc8cc10f91bca2f98a67dbd2c70
Deleted: sha256:98e92d3dedb9e6fa442c37645595680f8228552fa2142777f6c1690189a7e854
Deleted: sha256:13aad69c7e1db7a0326e640e31ec688200d18ba5e5bf43d5b35d8af912eff5a0
Deleted: sha256:b4aa32b9c828db5f37eccd745980832085bdf54fee545f12f6b967d32fd18baa
Deleted: sha256:37ece9e8f1c4dae950c0d085bc8501a93d63f0a7aff4bd8fb912083705c28701
Deleted: sha256:14921c30c87c3e662e30405f299447e38ec2d36e4a3ef2ff6e88559c5f35d3fa
Deleted: sha256:fc683ac7ab4b3e2b9c6fc38ed429a89009f482c948c029df362264a0ab0d3b9a
Deleted: sha256:d02ce8aa592827bdfe71c79a4d57f269451a92c29bf614a163ab7a579f97a6d8
Deleted: sha256:9f17c27b4ab5389746f8eae7474e6a0b11418755a904477628100f762a0dd2e8
Deleted: sha256:db919f39012463aa0e6e85b1138f4f132d816831ee5922802bb88e79b8c7de7b
Deleted: sha256:a4bb0b185d07e97b39fddb703ceb693bec441aa4e280ab5c4c25324e6200e25c
Deleted: sha256:6e3eda28c10efbf57b3e45264f521a87e55b5e4e92912a8d5b488e401764ab10
Deleted: sha256:52629a558487c01112a32b5219186316754f21302e3b2ef3cf42d21d33db9717
Deleted: sha256:34fd56ce9929b08117686224e928ae7d6d1da7f79b4cb7fda851f54d0aabd81b
Deleted: sha256:771509c4bbb06e4083456cfd92451a8b079f834876e5ee01e42b314d28b50921
Deleted: sha256:880f012440ab004d3af038be4b0230fbdcf8421836b3a75fd32e633dde1100ab
Deleted: sha256:e372e3ab7fb43943309803182e01450d4844e8d8157dbc6fe05d7ddefa1daacc
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a28571eb93e9ca321ad1b971632858d8fe490e383e2e0d53282ea0ecaf95c7a6
  Associated tags:
 - 20230319-203219
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-203219].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a28571eb93e9ca321ad1b971632858d8fe490e383e2e0d53282ea0ecaf95c7a6].
$ rm -rf /tmp/tmp.zl585hkfwc
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1d99503c95bc256e9a294fb093596cb880b8cee70e60341f208f0aeac891119].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1470006b03276a569588b0eb22437697dd6bc7d8f62794d6cd6fb697ce494623].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3864736.
Stopping expansion service pid: 3864737.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 40s
232 actionable tasks: 171 executed, 51 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1421

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1421/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319142028",
            "environmentId": "HFwWGAqZgybeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150"
      }
    ]
  },
  "name": "go-testxlang_partition-816",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/19 15:15:57 Submitted job: 2023-03-19_08_15_57-5401541913643419241
2023/03/19 15:15:57 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-19_08_15_57-5401541913643419241?project=apache-beam-testing
2023/03/19 15:15:57 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-19_08_15_57-5401541913643419241
2023/03/19 15:15:57 Job state: JOB_STATE_PENDING ...
2023/03/19 15:16:27 Job still running ...
2023/03/19 15:16:57 Job still running ...
2023/03/19 15:17:27 Job still running ...
2023/03/19 15:17:57 Job still running ...
2023/03/19 15:18:27 Job still running ...
2023/03/19 15:18:57 Job still running ...
2023/03/19 15:19:27 Job still running ...
2023/03/19 15:19:58 Job still running ...
2023/03/19 15:20:28 Job still running ...
2023/03/19 15:20:58 Job still running ...
2023/03/19 15:21:28 Job still running ...
2023/03/19 15:21:58 Job still running ...
2023/03/19 15:22:28 Job still running ...
2023/03/19 15:22:58 Job still running ...
2023/03/19 15:23:28 Job still running ...
2023/03/19 15:23:58 Job still running ...
2023/03/19 15:24:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-19_08_15_57-5401541913643419241 failed
--- FAIL: TestXLang_Partition (550.55s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3152.344s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679236349379322230
--- FAIL: TestBigQueryIO_BasicWriteRead (4.58s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37317 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ldxFQLNvwa" is_bounded:BOUNDED windowing_strategy_id:"w0@ldxFQLNvwa"}} windowing_strategies:{key:"w0@ldxFQLNvwa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ldxFQLNvwa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ldxFQLNvwa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ldxFQLNvwa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679236349379322230\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ldxFQLNvwa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37317 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ldxFQLNvwa" is_bounded:BOUNDED windowing_strategy_id:"w0@ldxFQLNvwa"}} windowing_strategies:{key:"w0@ldxFQLNvwa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ldxFQLNvwa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ldxFQLNvwa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ldxFQLNvwa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679236349379322230\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ldxFQLNvwa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0007115c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0007115c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000400a80?, 0xc000117a40?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc00041cbf0, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000400a20?, 0xc000117a40?}, {0xc0001188a0, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7f19985525d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00041cbf0, 0xf}, {0xc0001188a0, 0x52}, {0xebcb60, 0xc00041df00})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000425040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000425040, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.618s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.044s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4da65d0285d61c060b8df5919a385a04e91d17b7670f9ceea0372d158f2ebce0
Deleted: sha256:e4c0f6b19e9a74219bd0b89b285a3e14f23e557a39fb2986ff51aeb6b133b348
Deleted: sha256:768924eb86d93257141574c65af845499da59fc5cf60ab85dfa7a01a96356cf4
Deleted: sha256:64cba96aa1e62d5ac00df20d53351c1275f42fb04f4d018c4073de92a04e2a75
Deleted: sha256:f4db4514773a53c7a5d21926174ba2ebb9cfdc92354eabcb30ab85b0f4a1788d
Deleted: sha256:7a0407366cde862907b02aeea8b79df0b6148d4a44a5b5939084a46e4eaa02b3
Deleted: sha256:89865a1fd69933e98ebe1d006edab1b60cded3157a4b7f00db657111b1527ca3
Deleted: sha256:0667fcc650907631a80a187f89217f0c1ab035c8319d6c6302a69f4afa8e9ae0
Deleted: sha256:c2a5c7c957c55f93401a3fe41c251b0dae2a01639831cae3e9c9c4870239f652
Deleted: sha256:94e435ec10a51fc78901d5adcf38eec958a967fb3828f82d041dbe818718e348
Deleted: sha256:4b39e1d5f1ab6b58f599bc583f98fec87368aa519e9f608d4248e4d93dcced12
Deleted: sha256:dfe549fd86ad43e8ac2171404e19997ad186fe5ca027cde2a3dd036822587598
Deleted: sha256:313a46158bdc7af364f62d87dfd62808a8d44c70a27c37b2112a497ce4eaded0
Deleted: sha256:c353338a606582d5b1755a0081a96d90642d79658f797762d666da51f3e552d9
Deleted: sha256:ad9d480ba7912b17cdbd43e11f90da94c5077f9a74f6d315809e98d1a57bb66d
Deleted: sha256:b71b2230253c33bc44897c25f58e516b74f6d63b84ed9f65b885ec2f820474c6
Deleted: sha256:3ffb3e05a68a0b5f692d8ef07fa2cb13860292b74b7dc0a8b042971c82bc4050
Deleted: sha256:6069efe113fb0418376c2171eceeb057595a74c0899aeebb9d64e4b6fb818d76
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4da65d0285d61c060b8df5919a385a04e91d17b7670f9ceea0372d158f2ebce0
  Associated tags:
 - 20230319-143150
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-143150].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4da65d0285d61c060b8df5919a385a04e91d17b7670f9ceea0372d158f2ebce0].
$ rm -rf /tmp/tmp.QA2NjDfdMO
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319142028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319142028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319142028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3d6315497d7f2c3fe3fad41b895b663e1a92c25834e3d6186d317ec6b11f98bf].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319142028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319142028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319142028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:614d58f1f563d7e257b35a7178c5e3f3ce3c308cfa2c6d9ae423d94d7da1b72a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3665144.
Stopping expansion service pid: 3665145.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 57s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1420

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1420/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319082038",
            "environmentId": "qVOIvvbMiLbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155"
      }
    ]
  },
  "name": "go-testxlang_partition-46",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/19 09:16:24 Submitted job: 2023-03-19_02_16_24-12715345456241134970
2023/03/19 09:16:24 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-19_02_16_24-12715345456241134970?project=apache-beam-testing
2023/03/19 09:16:24 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-19_02_16_24-12715345456241134970
2023/03/19 09:16:24 Job state: JOB_STATE_PENDING ...
2023/03/19 09:16:54 Job still running ...
2023/03/19 09:17:24 Job still running ...
2023/03/19 09:17:54 Job still running ...
2023/03/19 09:18:24 Job still running ...
2023/03/19 09:18:54 Job still running ...
2023/03/19 09:19:24 Job still running ...
2023/03/19 09:19:54 Job still running ...
2023/03/19 09:20:24 Job still running ...
2023/03/19 09:20:54 Job still running ...
2023/03/19 09:21:25 Job still running ...
2023/03/19 09:21:55 Job still running ...
2023/03/19 09:22:25 Job still running ...
2023/03/19 09:22:55 Job still running ...
2023/03/19 09:23:25 Job still running ...
2023/03/19 09:23:55 Job still running ...
2023/03/19 09:24:25 Job still running ...
2023/03/19 09:24:55 Job still running ...
2023/03/19 09:25:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-19_02_16_24-12715345456241134970 failed
--- FAIL: TestXLang_Partition (580.78s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3206.124s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679214752556647234
--- FAIL: TestBigQueryIO_BasicWriteRead (4.42s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37325 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BRmpeCWvuf" is_bounded:BOUNDED windowing_strategy_id:"w0@BRmpeCWvuf"}} windowing_strategies:{key:"w0@BRmpeCWvuf" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BRmpeCWvuf" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BRmpeCWvuf" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BRmpeCWvuf" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679214752556647234\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BRmpeCWvuf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37325 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BRmpeCWvuf" is_bounded:BOUNDED windowing_strategy_id:"w0@BRmpeCWvuf"}} windowing_strategies:{key:"w0@BRmpeCWvuf" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BRmpeCWvuf" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BRmpeCWvuf" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BRmpeCWvuf" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679214752556647234\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BRmpeCWvuf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00002c1c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00002c1c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000408600?, 0xc000138230?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000131730, 0xf}, 0xc0000f3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004085a0?, 0xc000138230?}, {0xc00010e840, 0x52}, {0x1?}, {0xc0000f3ea8, 0x2, 0x7fb21fd70448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131730, 0xf}, {0xc00010e840, 0x52}, {0xebcb60, 0xc000042250})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000602d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000602d00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.450s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:78d66b970efb7e8ac9674154087171345441b8143ffbb84700184c6d1784c223
Deleted: sha256:64c389db173e25d4e633c2886482c9446311a245bd8f6dd0bfc2e23bf780f99c
Deleted: sha256:0e2fcba51ca439fce26ec94223ec1f1e0c0f2e2c5ba81e74561834ab91c478fc
Deleted: sha256:510777983bc6aae4bc247db48faf44d25f0d048c000aaa816464477b7c251a90
Deleted: sha256:1aa96b5abaac743d37cd526f5e5b98545c4099e03383eaab8d253e29e16f887f
Deleted: sha256:cd49ef099a86ae6d6fb344c207179bf3c510da7a17eb78e5b4e757d9ad2a7534
Deleted: sha256:551d18feb3a1b830302e64b17cd824c3e33666530d14269af13db48d87f61b54
Deleted: sha256:91d0286d85d32b6c842ee6c9d6b1de46c139fd4ecb58a88db0f8718c19938881
Deleted: sha256:e3771a57b9cf67bfafa79bc2c8f81cdd936be5f9ba72e79e05bc286897bffd43
Deleted: sha256:a01f3a4b7f7785724a9c4e4b4bf5aac838ddbb5ad6afa1e970c0c51c36538c8f
Deleted: sha256:4d70bce908e0a54c753146489859d96e053359caafa0442c222ccee1eccb0520
Deleted: sha256:5a6ce0d23fb901c3968aa5a304061c62e16f1794b1c76002742a48f04020fd3a
Deleted: sha256:13a05daecc987b3632875bd0d95c225afddae261707edf8aae4e036eb1b48980
Deleted: sha256:e5a2888355f2da897bb2e1f1f7155306fa1de6809f9d136041e615f8b8989ddc
Deleted: sha256:e9c030b02015ef809c74cf44b8a7b509d93b243522682836527ae5de040a16ec
Deleted: sha256:73b0443ae0c969c83afafd6ba020075eb4a83825da0137b7307a1a0b8551c4bb
Deleted: sha256:d3778066eb654f55558d7313f60bf77561e8e99a7e1f748bd63d874643302942
Deleted: sha256:e2f52cc2959e5c4f53067f92a9b252b202d13860dbc1e1ec542155a7c65ed52f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:78d66b970efb7e8ac9674154087171345441b8143ffbb84700184c6d1784c223
  Associated tags:
 - 20230319-083155
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-083155].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:78d66b970efb7e8ac9674154087171345441b8143ffbb84700184c6d1784c223].
$ rm -rf /tmp/tmp.dnPfC5lH7W
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319082038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dd330e26adfa0ee5429c97c90df9134f1bc2244a2e7b80f2d31b065e47cbe2ba].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319082038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:172fcdb7a4083ee2f117f6ba320943005b28c9dc836d70d29cfd0981808c7c7e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3480184.
Stopping expansion service pid: 3480185.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 42s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1419

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1419/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-023151",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319022038",
            "environmentId": "pJvFQIqTPvbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-023151"
      }
    ]
  },
  "name": "go-testxlang_partition-799",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/19 03:17:25 Submitted job: 2023-03-18_20_17_25-4361867820299233590
2023/03/19 03:17:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-18_20_17_25-4361867820299233590?project=apache-beam-testing
2023/03/19 03:17:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-18_20_17_25-4361867820299233590
2023/03/19 03:17:25 Job state: JOB_STATE_PENDING ...
2023/03/19 03:17:55 Job still running ...
2023/03/19 03:18:25 Job still running ...
2023/03/19 03:18:55 Job still running ...
2023/03/19 03:19:25 Job still running ...
2023/03/19 03:19:56 Job still running ...
2023/03/19 03:20:26 Job still running ...
2023/03/19 03:20:56 Job still running ...
2023/03/19 03:21:26 Job still running ...
2023/03/19 03:21:56 Job still running ...
2023/03/19 03:22:26 Job still running ...
2023/03/19 03:22:56 Job still running ...
2023/03/19 03:23:26 Job still running ...
2023/03/19 03:23:56 Job still running ...
2023/03/19 03:24:26 Job still running ...
2023/03/19 03:24:56 Job still running ...
2023/03/19 03:25:26 Job still running ...
2023/03/19 03:25:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-18_20_17_25-4361867820299233590 failed
--- FAIL: TestXLang_Partition (550.56s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3237.931s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679193152117802125
--- FAIL: TestBigQueryIO_BasicWriteRead (4.30s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32877 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oNkkKTLKMG" is_bounded:BOUNDED windowing_strategy_id:"w0@oNkkKTLKMG"}} windowing_strategies:{key:"w0@oNkkKTLKMG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oNkkKTLKMG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oNkkKTLKMG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oNkkKTLKMG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679193152117802125\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oNkkKTLKMG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32877 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oNkkKTLKMG" is_bounded:BOUNDED windowing_strategy_id:"w0@oNkkKTLKMG"}} windowing_strategies:{key:"w0@oNkkKTLKMG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oNkkKTLKMG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oNkkKTLKMG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oNkkKTLKMG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679193152117802125\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oNkkKTLKMG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 42 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000028d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000028d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00059e620?, 0xc0005b0000?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc000137660, 0xf}, 0xc000033d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00059e5c0?, 0xc0005b0000?}, {0xc000018360, 0x52}, {0x1?}, {0xc000033ea8, 0x2, 0x7f8460a2bd40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137660, 0xf}, {0xc000018360, 0x52}, {0xebcb60, 0xc000598140})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0002fe820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0002fe820, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.332s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8d78ae69bd7a08f2c84923f82ccdc7362f3b50f62d20766ec36c79d7a2a579bb
  Associated tags:
 - 20230319-023151
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-023151
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230319-023151].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8d78ae69bd7a08f2c84923f82ccdc7362f3b50f62d20766ec36c79d7a2a579bb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:769efdc393b0b52cef5faa94744240e33eedce6b24dec4f6c7fe4990434d04dc]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230319022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:769efdc393b0b52cef5faa94744240e33eedce6b24dec4f6c7fe4990434d04dc])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:769efdc393b0b52cef5faa94744240e33eedce6b24dec4f6c7fe4990434d04dc
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:769efdc393b0b52cef5faa94744240e33eedce6b24dec4f6c7fe4990434d04dc].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:56ec95f223352f129dc9f32ae81acac1df1a4fe9a1a29102b49962f48a4ab96a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230319022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:56ec95f223352f129dc9f32ae81acac1df1a4fe9a1a29102b49962f48a4ab96a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:56ec95f223352f129dc9f32ae81acac1df1a4fe9a1a29102b49962f48a4ab96a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:56ec95f223352f129dc9f32ae81acac1df1a4fe9a1a29102b49962f48a4ab96a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 13s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1418

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1418/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318202041",
            "environmentId": "IsfhVkruQJbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251"
      }
    ]
  },
  "name": "go-testxlang_partition-102",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/18 21:18:02 Submitted job: 2023-03-18_14_18_02-11885965892242202416
2023/03/18 21:18:02 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-18_14_18_02-11885965892242202416?project=apache-beam-testing
2023/03/18 21:18:02 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-18_14_18_02-11885965892242202416
2023/03/18 21:18:02 Job state: JOB_STATE_PENDING ...
2023/03/18 21:18:32 Job still running ...
2023/03/18 21:19:02 Job still running ...
2023/03/18 21:19:32 Job still running ...
2023/03/18 21:20:03 Job still running ...
2023/03/18 21:20:33 Job still running ...
2023/03/18 21:21:03 Job still running ...
2023/03/18 21:21:33 Job still running ...
2023/03/18 21:22:03 Job still running ...
2023/03/18 21:22:33 Job still running ...
2023/03/18 21:23:03 Job still running ...
2023/03/18 21:23:33 Job still running ...
2023/03/18 21:24:03 Job still running ...
2023/03/18 21:24:33 Job still running ...
2023/03/18 21:25:03 Job still running ...
2023/03/18 21:25:33 Job still running ...
2023/03/18 21:26:03 Job still running ...
2023/03/18 21:26:33 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-18_14_18_02-11885965892242202416 failed
--- FAIL: TestXLang_Partition (550.99s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3216.161s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679171611011763676
--- FAIL: TestBigQueryIO_BasicWriteRead (6.47s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46005 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@GseIDvtjAz" is_bounded:BOUNDED windowing_strategy_id:"w0@GseIDvtjAz"}} windowing_strategies:{key:"w0@GseIDvtjAz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@GseIDvtjAz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@GseIDvtjAz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@GseIDvtjAz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679171611011763676\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"GseIDvtjAz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46005 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@GseIDvtjAz" is_bounded:BOUNDED windowing_strategy_id:"w0@GseIDvtjAz"}} windowing_strategies:{key:"w0@GseIDvtjAz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@GseIDvtjAz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@GseIDvtjAz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@GseIDvtjAz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679171611011763676\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"GseIDvtjAz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000497d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000497d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a66c0?, 0xc0005ba000?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc000042d30, 0xf}, 0xc00067bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6660?, 0xc0005ba000?}, {0xc000650300, 0x52}, {0x1?}, {0xc00067bea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d30, 0xf}, {0xc000650300, 0x52}, {0xebcb60, 0xc0004941d8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00059f380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00059f380, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.510s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.055s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.106s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.057s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29bb821742152175ac450214bc6547e3e206c040d09745e94a6ccee770e2801b
Deleted: sha256:8d9f9b8b0aaf48d30c4e42fc71df2a77a6fbac6f55145cf498242e05f1bda4ca
Deleted: sha256:9ae8144e41926a98914923ed2fdb2928f4ca9a46e1759e4152a10326c801b188
Deleted: sha256:864100f3f72aa22290cb4334465be2acf2eb4e80305a3f1be2357c40d53b8bf8
Deleted: sha256:e19972286499e267db3e40186da99419ea67e6a2645439d88a528b4e3de672b0
Deleted: sha256:7faf15a26cdf17eb286cc1c5948d7594fcb0bccf9a86d135fe9adce22557eb18
Deleted: sha256:9a302c4b482b1a5945c316faef34045fffe2286511607245f47a4cae5d33caa2
Deleted: sha256:d1d9107c5b0f2913147baffa494a10089b84a79685264a8769b6314747dbc9a5
Deleted: sha256:2ef1df509044281507d04ddf005bc20eeae8bf3f9947c34dfb616f8a8dbe09d3
Deleted: sha256:6501b7da29a9fde5e12940c8b3780be0615d8da0a2f2617a538e443c59ab1195
Deleted: sha256:e8f6671d5a80cfff768e6de9383df718df7bbe8b37a3ca8176cb22aae31ff8a6
Deleted: sha256:d4f9d413b97e8a15834f7ebfa2b2ef2298b5242f19e0f80c181a760a053c902e
Deleted: sha256:faa0359d8a0606e1450bbb795a6eb6c5afa53e37ef7899dac4a0cef7b01e1b55
Deleted: sha256:28d44bc1e00db071c6f5a9eed8a11599055c8bf5bc6f11569c93d4fb20538b2e
Deleted: sha256:0a60082d5c12d0d0b5cf77a845c58795172ff54147ee67924bf45accfc7a8e07
Deleted: sha256:46e84b20e2b18219b8783c343c070c7510b85ee35f0022276ca27bcad9eea714
Deleted: sha256:0d874972833ee222731bca7de3657644083026358baca44dbbf6a4ad1658f4e9
Deleted: sha256:ed39dbcb291bf90956920f1c855dfe6756582ccab37d826f5243c8f29435cc17
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29bb821742152175ac450214bc6547e3e206c040d09745e94a6ccee770e2801b
  Associated tags:
 - 20230318-203251
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-203251].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:29bb821742152175ac450214bc6547e3e206c040d09745e94a6ccee770e2801b].
$ rm -rf /tmp/tmp.m92W2lFZMP
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d42c69bc045c855a28fea51356d950f231e1d5ce11aa3d514969b8d8cdd5fec8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318202041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318202041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318202041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:be175cc65f1dc285e215ac1624e38573b6c96d08dde50631f17430d8b6246622].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3194763.
Stopping expansion service pid: 3194764.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 49s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1417

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1417/display/redirect>

Changes:


------------------------------------------
[...truncated 1003.02 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-143155",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318142041",
            "environmentId": "zpLeSpUWCfbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-143155"
      }
    ]
  },
  "name": "go-testxlang_partition-393",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/18 15:16:56 Submitted job: 2023-03-18_08_16_56-1000775003656716179
2023/03/18 15:16:56 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-18_08_16_56-1000775003656716179?project=apache-beam-testing
2023/03/18 15:16:56 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-18_08_16_56-1000775003656716179
2023/03/18 15:16:56 Job state: JOB_STATE_PENDING ...
2023/03/18 15:17:26 Job still running ...
2023/03/18 15:17:56 Job still running ...
2023/03/18 15:18:26 Job still running ...
2023/03/18 15:18:56 Job still running ...
2023/03/18 15:19:26 Job still running ...
2023/03/18 15:19:57 Job still running ...
2023/03/18 15:20:27 Job still running ...
2023/03/18 15:20:57 Job still running ...
2023/03/18 15:21:27 Job still running ...
2023/03/18 15:21:57 Job still running ...
2023/03/18 15:22:27 Job still running ...
2023/03/18 15:22:57 Job still running ...
2023/03/18 15:23:27 Job still running ...
2023/03/18 15:23:57 Job still running ...
2023/03/18 15:24:27 Job still running ...
2023/03/18 15:24:57 Job still running ...
2023/03/18 15:25:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-18_08_16_56-1000775003656716179 failed
--- FAIL: TestXLang_Partition (552.05s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.697s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679149951539445002
--- FAIL: TestBigQueryIO_BasicWriteRead (4.61s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42945 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zSIeMBkTgi" is_bounded:BOUNDED windowing_strategy_id:"w0@zSIeMBkTgi"}} windowing_strategies:{key:"w0@zSIeMBkTgi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zSIeMBkTgi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zSIeMBkTgi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zSIeMBkTgi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679149951539445002\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zSIeMBkTgi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42945 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zSIeMBkTgi" is_bounded:BOUNDED windowing_strategy_id:"w0@zSIeMBkTgi"}} windowing_strategies:{key:"w0@zSIeMBkTgi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zSIeMBkTgi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zSIeMBkTgi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zSIeMBkTgi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679149951539445002\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zSIeMBkTgi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0003fe900})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0003fe900})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001693c0?, 0xc0001399f0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000131630, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169360?, 0xc0001399f0?}, {0xc00010e900, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f9596c9ee50?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131630, 0xf}, {0xc00010e900, 0x52}, {0xebcb60, 0xc000196940})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005c2d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005c2d00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.648s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eb5ca238eb8a07d7dc45991648b85fab07c3393d43f7fbe67bd0bff3b40ff0eb
  Associated tags:
 - 20230318-143155
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-143155
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-143155].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eb5ca238eb8a07d7dc45991648b85fab07c3393d43f7fbe67bd0bff3b40ff0eb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:258a56007245aa927d2314b6d345fad28d75b114bfaa3715b6ca8d95fadbd6a7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:258a56007245aa927d2314b6d345fad28d75b114bfaa3715b6ca8d95fadbd6a7])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:258a56007245aa927d2314b6d345fad28d75b114bfaa3715b6ca8d95fadbd6a7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:258a56007245aa927d2314b6d345fad28d75b114bfaa3715b6ca8d95fadbd6a7].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:22817967b6c46dfee625a53c2b218ae608469c51cc0581cb0628eb8cad1c5a82]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:22817967b6c46dfee625a53c2b218ae608469c51cc0581cb0628eb8cad1c5a82])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:22817967b6c46dfee625a53c2b218ae608469c51cc0581cb0628eb8cad1c5a82
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:22817967b6c46dfee625a53c2b218ae608469c51cc0581cb0628eb8cad1c5a82].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 43s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1416

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1416/display/redirect>

Changes:


------------------------------------------
[...truncated 541.06 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-083227",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318082046",
            "environmentId": "qryTAxSSzKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-083227"
      }
    ]
  },
  "name": "go-testxlang_partition-153",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/18 09:15:04 Submitted job: 2023-03-18_02_15_03-6151207534294644524
2023/03/18 09:15:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-18_02_15_03-6151207534294644524?project=apache-beam-testing
2023/03/18 09:15:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-18_02_15_03-6151207534294644524
2023/03/18 09:15:04 Job state: JOB_STATE_PENDING ...
2023/03/18 09:15:34 Job still running ...
2023/03/18 09:16:04 Job still running ...
2023/03/18 09:16:34 Job still running ...
2023/03/18 09:17:04 Job still running ...
2023/03/18 09:17:34 Job still running ...
2023/03/18 09:18:04 Job still running ...
2023/03/18 09:18:34 Job still running ...
2023/03/18 09:19:04 Job still running ...
2023/03/18 09:19:34 Job still running ...
2023/03/18 09:20:04 Job still running ...
2023/03/18 09:20:34 Job still running ...
2023/03/18 09:21:04 Job still running ...
2023/03/18 09:21:34 Job still running ...
2023/03/18 09:22:04 Job still running ...
2023/03/18 09:22:34 Job still running ...
2023/03/18 09:23:05 Job still running ...
2023/03/18 09:23:35 Job still running ...
2023/03/18 09:24:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-18_02_15_03-6151207534294644524 failed
--- FAIL: TestXLang_Partition (581.63s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3091.881s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679128386735354065
--- FAIL: TestBigQueryIO_BasicWriteRead (4.68s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41751 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ynNsnvmIbl" is_bounded:BOUNDED windowing_strategy_id:"w0@ynNsnvmIbl"}} windowing_strategies:{key:"w0@ynNsnvmIbl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ynNsnvmIbl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ynNsnvmIbl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ynNsnvmIbl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679128386735354065\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ynNsnvmIbl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41751 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ynNsnvmIbl" is_bounded:BOUNDED windowing_strategy_id:"w0@ynNsnvmIbl"}} windowing_strategies:{key:"w0@ynNsnvmIbl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ynNsnvmIbl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ynNsnvmIbl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ynNsnvmIbl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679128386735354065\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ynNsnvmIbl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00049ee40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00049ee40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000124ca0?, 0xc00012b770?}, {0x113b23e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc000127000, 0xf}, 0xc000163d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000124c40?, 0xc00012b770?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc000163ea8, 0x2, 0x7fd2039b2ed8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000127000, 0xf}, {0xc00004c5a0, 0x52}, {0xebcb60, 0xc000166310})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a4680)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a4680, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.721s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dfd29e183e7fe32c908e3fc0084fb4d7cd9e84d14d63498e2715aa6a68fdc9e6
  Associated tags:
 - 20230318-083227
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-083227
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-083227].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:dfd29e183e7fe32c908e3fc0084fb4d7cd9e84d14d63498e2715aa6a68fdc9e6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318082046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353d243841381dfefc19ec289c3b1cb46eada8087da28a12a32e43485613085a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318082046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353d243841381dfefc19ec289c3b1cb46eada8087da28a12a32e43485613085a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353d243841381dfefc19ec289c3b1cb46eada8087da28a12a32e43485613085a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353d243841381dfefc19ec289c3b1cb46eada8087da28a12a32e43485613085a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318082046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a187662c45bf26c86cc9b446bf25efc8f8d9ab818632e8447edc4da90869e6f5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318082046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a187662c45bf26c86cc9b446bf25efc8f8d9ab818632e8447edc4da90869e6f5])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a187662c45bf26c86cc9b446bf25efc8f8d9ab818632e8447edc4da90869e6f5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a187662c45bf26c86cc9b446bf25efc8f8d9ab818632e8447edc4da90869e6f5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 18s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1415

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1415/display/redirect>

Changes:


------------------------------------------
[...truncated 1023.71 KB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318022029",
            "environmentId": "WkLUQIDnJPbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205"
      }
    ]
  },
  "name": "go-testxlang_partition-878",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/18 03:17:09 Submitted job: 2023-03-17_20_17_08-9833114066812369843
2023/03/18 03:17:09 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-17_20_17_08-9833114066812369843?project=apache-beam-testing
2023/03/18 03:17:09 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-17_20_17_08-9833114066812369843
2023/03/18 03:17:09 Job state: JOB_STATE_PENDING ...
2023/03/18 03:17:39 Job still running ...
2023/03/18 03:18:09 Job still running ...
2023/03/18 03:18:39 Job still running ...
2023/03/18 03:19:09 Job still running ...
2023/03/18 03:19:39 Job still running ...
2023/03/18 03:20:09 Job still running ...
2023/03/18 03:20:39 Job still running ...
2023/03/18 03:21:09 Job still running ...
2023/03/18 03:21:39 Job still running ...
2023/03/18 03:22:09 Job still running ...
2023/03/18 03:22:39 Job still running ...
2023/03/18 03:23:09 Job still running ...
2023/03/18 03:23:39 Job still running ...
2023/03/18 03:24:09 Job still running ...
2023/03/18 03:24:39 Job still running ...
2023/03/18 03:25:09 Job still running ...
2023/03/18 03:25:39 Job still running ...
2023/03/18 03:26:09 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-17_20_17_08-9833114066812369843 failed
--- FAIL: TestXLang_Partition (580.95s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3240.950s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679106762053335150
--- FAIL: TestBigQueryIO_BasicWriteRead (4.65s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wvefPeFksP" is_bounded:BOUNDED windowing_strategy_id:"w0@wvefPeFksP"}} windowing_strategies:{key:"w0@wvefPeFksP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wvefPeFksP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wvefPeFksP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wvefPeFksP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679106762053335150\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wvefPeFksP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wvefPeFksP" is_bounded:BOUNDED windowing_strategy_id:"w0@wvefPeFksP"}} windowing_strategies:{key:"w0@wvefPeFksP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wvefPeFksP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wvefPeFksP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wvefPeFksP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679106762053335150\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wvefPeFksP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 21 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000629a00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000629a00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004fe800?, 0xc00041a050?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000131710, 0xf}, 0xc000645d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004fe7a0?, 0xc00041a050?}, {0xc000616300, 0x52}, {0x1?}, {0xc000645ea8, 0x2, 0x7fdb1c047a18?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131710, 0xf}, {0xc000616300, 0x52}, {0xebcb60, 0xc000000180})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001baea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001baea0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.682s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:64d96675a27020594682617d27c7bf7c1896f2aa0a19d15006cce38888fc659b
Deleted: sha256:fcc29d61126c86819cbb80c631ba7ef1ca75f4ee81e233f02734103125a794d8
Deleted: sha256:7cdb54389d5c224a6602ac68c32a85a5c8e34fe68b939d7736c2c8ca664fd9f7
Deleted: sha256:73926dd4c5c9fe13a9a680d9b3efaeb31d0ae5563ab472495a08f85f417a0d3a
Deleted: sha256:f1d80d1b7150e9aef85486473b4ce0615f8951fd1a824d86656675a891b7ceee
Deleted: sha256:834b250d9b655032b43a72de8376d1fd3b3c777ed2bce9db0b57366e076abb91
Deleted: sha256:0ca6750f9dcd9fcae5bb880c24f67f90b4a54d66faed43b5b975a1ca28774f79
Deleted: sha256:210aaec0e2cd3a54d88ee5444ea54a93ccf7b4f4e25be86a2714653fef7ae682
Deleted: sha256:0ba5ef44c132adba8f16e20cee20eb1e52e6023a4c13521ff2ffc779c6eb8807
Deleted: sha256:40f4e2fdd2b90e77a9a7dc0c3d262e8e13081ab796baa310afe0ee104941034d
Deleted: sha256:949e5208d28f15c20009a5f5b19faa08036e7f453de8e88e235415cc0ccc3824
Deleted: sha256:7c8d288762acff7b3c2c23c19c0780b530c380e8e560e104330b8daf62667eab
Deleted: sha256:bbfa8ecc11fe70253ab90e1930c7e81f3536b40fd82d113a947e2e05382b74e0
Deleted: sha256:5e533fb20a7a521c9580a02be7937a7edc609eaa674548bc78fd9222b570a574
Deleted: sha256:697a98167c0f220212dbff5df4dbd9c5607d259872f5ad28422662d6815b4e63
Deleted: sha256:ca94e7a4713ce51432f2ae53899c20e797a901787b53cf3dc49895892c54913b
Deleted: sha256:42c601a189d28adbaf1752881ceafd7f4d955f2442954e1a752fd577adc5837e
Deleted: sha256:b811f9a9e3755319d97db7e27f5ae86824d346e687f3857979e0e802be7da97c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:64d96675a27020594682617d27c7bf7c1896f2aa0a19d15006cce38888fc659b
  Associated tags:
 - 20230318-023205
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230318-023205].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:64d96675a27020594682617d27c7bf7c1896f2aa0a19d15006cce38888fc659b].
$ rm -rf /tmp/tmp.bjNqwizlDt
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318022029
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318022029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230318022029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b819cae9d8c2d3cc8ba764acaed03f5a2b20b1983236cefaba0bfda4b36813f7].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318022029
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318022029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230318022029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1fca0ed73895c11f475c08e7992c1f5a3e1ae0b4d916b34c6a2e5cfb0293bec5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2725757.
Stopping expansion service pid: 2725758.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 36s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1414

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1414/display/redirect>

Changes:


------------------------------------------
[...truncated 555.41 KB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317202029",
            "environmentId": "KUWahVdKwHbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211"
      }
    ]
  },
  "name": "go-testxlang_partition-167",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/17 21:21:18 Submitted job: 2023-03-17_14_21_18-4379619161122427366
2023/03/17 21:21:18 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-17_14_21_18-4379619161122427366?project=apache-beam-testing
2023/03/17 21:21:18 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-17_14_21_18-4379619161122427366
2023/03/17 21:21:18 Job state: JOB_STATE_PENDING ...
2023/03/17 21:21:48 Job still running ...
2023/03/17 21:22:18 Job still running ...
2023/03/17 21:22:48 Job still running ...
2023/03/17 21:23:18 Job still running ...
2023/03/17 21:23:48 Job still running ...
2023/03/17 21:24:18 Job still running ...
2023/03/17 21:24:48 Job still running ...
2023/03/17 21:25:18 Job still running ...
2023/03/17 21:25:48 Job still running ...
2023/03/17 21:26:19 Job still running ...
2023/03/17 21:26:49 Job still running ...
2023/03/17 21:27:19 Job still running ...
2023/03/17 21:27:49 Job still running ...
2023/03/17 21:28:19 Job still running ...
2023/03/17 21:28:49 Job still running ...
2023/03/17 21:29:19 Job still running ...
2023/03/17 21:29:49 Job still running ...
2023/03/17 21:30:19 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-17_14_21_18-4379619161122427366 failed
--- FAIL: TestXLang_Partition (580.63s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3484.096s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679085168595783676
--- FAIL: TestBigQueryIO_BasicWriteRead (5.29s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42137 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rDfDkNbyim" is_bounded:BOUNDED windowing_strategy_id:"w0@rDfDkNbyim"}} windowing_strategies:{key:"w0@rDfDkNbyim" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rDfDkNbyim" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rDfDkNbyim" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rDfDkNbyim" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679085168595783676\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rDfDkNbyim"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42137 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rDfDkNbyim" is_bounded:BOUNDED windowing_strategy_id:"w0@rDfDkNbyim"}} windowing_strategies:{key:"w0@rDfDkNbyim" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rDfDkNbyim" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rDfDkNbyim" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rDfDkNbyim" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679085168595783676\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rDfDkNbyim"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0002e0400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0002e0400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0007029c0?, 0xc00012f770?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000704b90, 0xf}, 0xc000739d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000702960?, 0xc00012f770?}, {0xc00070a360, 0x52}, {0x1?}, {0xc000739ea8, 0x2, 0x7f2ddc675208?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000704b90, 0xf}, {0xc00070a360, 0x52}, {0xebcb60, 0xc000705ea0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006429c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006429c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.320s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9efb49ec2eca0bb00610dde89a01c244760cdfc10d1b6a8d43e4110d84f8641d
Deleted: sha256:c7e23f92e1152c632dbedecc0df9758d1a68574092c2822f6fb143c2c334610a
Deleted: sha256:45aef89b190bed095fc7dfd60e46f136a69ded769db4edf6e4018180272862f2
Deleted: sha256:1a5422c0c6ad20aab2893dbd7724905a9cc5120ca8e50517a7dce126796bd66f
Deleted: sha256:8f27cbb6d2663ab6ce747bd9f9daeae57c163770e8c9b1a7624897f60597c655
Deleted: sha256:26e72d67b70c724774d48ed4dfe402690f71f8d89605acf274e554decddd99d2
Deleted: sha256:31dc69fde1ce357bfefecb1f9f0809695ecba1afba7e6d08e9759fd47bc3eebd
Deleted: sha256:b1ec12e3402834879b845a04170f528c2b36929763ee2963261462fc99de67a8
Deleted: sha256:2548530a7dc3db862c5efacf21d81ff1ba48f5f6eae8c3af05fa022031ac284a
Deleted: sha256:16a55463083c54f3a6b986e8b32830d80a5145f1153209848de51c2505c09610
Deleted: sha256:869fc95641cca45911807fa181f9c3ee3fdf4ee593bc80fc9e54f5f2e6569c51
Deleted: sha256:46d1c24837d4370f7661b125506eae3f01a8b2390c0575953126391374bb149d
Deleted: sha256:cb51664fc26fe1266d08732eb1fac879161202b38f9ea14f812e5bfc7bd3829f
Deleted: sha256:a65c496e01a2afcb429086b76c92e390e3d9f6802fdcc40c4808e79f0bd2f202
Deleted: sha256:01f8aea6ba0af3f0ae1404c830ef25fd9337a130ed63468ddb79d30e873019be
Deleted: sha256:15059b06a593ed56b60edc44603d7e67fae6f86d4a0a388233a5fe9a581871a2
Deleted: sha256:373db1cc3525f15822bfaf93886ec5eb4d857ca63237ee04ee3e7095fc95fdc4
Deleted: sha256:f524a0156255b5b9b9f0aa4d3d6e488ed4f61281412d15ed8f64db59eb45e183
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9efb49ec2eca0bb00610dde89a01c244760cdfc10d1b6a8d43e4110d84f8641d
  Associated tags:
 - 20230317-203211
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-203211].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9efb49ec2eca0bb00610dde89a01c244760cdfc10d1b6a8d43e4110d84f8641d].
$ rm -rf /tmp/tmp.M7ZSjBlWTp
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317202029
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317202029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317202029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb16f5efff1f460f4a1a8b36070a65c3ae21617f29473856228c28259ff54f80].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317202029
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317202029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317202029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43da886c77843a7efdec802815888009eac8167e6eacbdea73e6ca8a2d813e14].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1960847.
Stopping expansion service pid: 1960848.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 49s
232 actionable tasks: 165 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1413

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1413/display/redirect?page=changes>

Changes:

[noreply] Upgrade tox from 3.x.x to 4.x.x (#25785)


------------------------------------------
[...truncated 1.01 MB...]
2023/03/17 15:24:41 Job still running ...
2023/03/17 15:25:11 Job still running ...
2023/03/17 15:25:41 Job still running ...
2023/03/17 15:26:11 Job still running ...
2023/03/17 15:26:41 Job still running ...
2023/03/17 15:27:11 Job still running ...
2023/03/17 15:27:41 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-17_08_19_10-8888668651178699633 failed
--- FAIL: TestXLang_Partition (551.14s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3186.670s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679063714453724811
--- FAIL: TestBigQueryIO_BasicWriteRead (5.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YQfwXYbSDn" is_bounded:BOUNDED windowing_strategy_id:"w0@YQfwXYbSDn"}} windowing_strategies:{key:"w0@YQfwXYbSDn" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YQfwXYbSDn" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YQfwXYbSDn" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YQfwXYbSDn" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679063714453724811\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YQfwXYbSDn"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YQfwXYbSDn" is_bounded:BOUNDED windowing_strategy_id:"w0@YQfwXYbSDn"}} windowing_strategies:{key:"w0@YQfwXYbSDn" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YQfwXYbSDn" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YQfwXYbSDn" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YQfwXYbSDn" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679063714453724811\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YQfwXYbSDn"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000382240})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000382240})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040abe0?, 0xc0000bda40?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc0005cebd0, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040ab80?, 0xc0000bda40?}, {0xc0005d4300, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f1912636800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005cebd0, 0xf}, {0xc0005d4300, 0x52}, {0xebcb60, 0xc0005cfee0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005c29c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005c29c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.569s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.039s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-143427
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-143427
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40d38d169ceeb6900a7df96d2d03f0c52b024baa19f313804784110c63a20253
Deleted: sha256:89b5c52e84ad2110fc2c41f6a57b36bcdd5a82f7d3f232716a93bd567308561c
Deleted: sha256:0d2ba70819e239957357022b217eb716dc3baa09b44dedfc9237a9ee305f8050
Deleted: sha256:afb5beebc9877d9c0860a5c7abb72816b22591341e21c51d15ac67f70fa4946b
Deleted: sha256:b8f7fc34b3d23a5e66bad5de1058f7d418f86736313f885d740e4c084cf16b02
Deleted: sha256:c482d19b19c7df7d1e090f3ab5a10ced4b28bf1be9f2142b4773c43ddf4f6d14
Deleted: sha256:84d8819be2d9c44efb28dfdf75e6098d21ba36d60a8c3083e987d50d1260481d
Deleted: sha256:1206a00f24a1ac95ff7070b03d3f01e2bbdc01902fb5fc2f5db147b01ad29a12
Deleted: sha256:e5502ced642f3d83c59ef32d807b040f11de9d0d0d2fb96ed940386f21c86535
Deleted: sha256:1e53e9d90196441664072bcf0b43a48d4c37cb7c98a527f9fff4b74e8f9e5190
Deleted: sha256:e7301e6dc8656c6dfd0be586d4b3ba21253e528039b54d0c908bab84f54eb7fc
Deleted: sha256:15e12a192cc5997409d8d69b3f98a66ccb7efaafd06c4ba0b4e8c7f6f9bbb749
Deleted: sha256:47dcc519ac20cedcb98954090eb226c8c78af3df1939871405c49011a0d85aaa
Deleted: sha256:f4e75733568dc191eabe8ee11a62066fc2295398277353a1e851221192c00744
Deleted: sha256:47ce4637536d644289ee4006d85810a23139afcd3a14eea056ce177680541819
Deleted: sha256:8daba3c893083aad109871eb21ff7f200e4b50ef8062b50f5aa4922f69ba6538
Deleted: sha256:e420d67b1eb326d17f6a9dbcbc9255d54b2e99d71980defaa6ee7ba80dfd928c
Deleted: sha256:9f8d27b2c4ab90fa744460ab516221dba02cfdff675a68bb426a50ca326f6739
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-143427
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40d38d169ceeb6900a7df96d2d03f0c52b024baa19f313804784110c63a20253
  Associated tags:
 - 20230317-143427
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-143427
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-143427].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:40d38d169ceeb6900a7df96d2d03f0c52b024baa19f313804784110c63a20253].
$ rm -rf /tmp/tmp.qeHJNoUljg
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317142042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f5b7c419075c3656a7174cfb8de27cd3ea61b0fafd149b98b293a05513795fb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317142042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987
Deleted: sha256:f950e953df4279c8d2568708c82c56168486557aa8718232676abaca929e1931
Deleted: sha256:3af586f4655956b311950bc6757a7adbce38f6cbad57f9e86a7ee9c33b4983f5
Deleted: sha256:ed0d88a6bdb8adb56f7bb325df6f9871d04e97ec760faf72a6482e1135886454
Deleted: sha256:9ee7eb3f95937af66610feb30e06bd6f80503b2808506611e346adf0e9def63b
Deleted: sha256:f9fe633dbd6d77dcb5f86af4cb2dcdce7134a39f00f34c01a3e0c2085167dc6e
Deleted: sha256:5b28597249f89ff253066abaeda846753d83560fcd78c8b740b1c896d74908b1
Deleted: sha256:dbf4e201a0ca6073c20a309f10a6537d16511120e2a38c0969462b5d09a7dc68
Deleted: sha256:2de109e969000e17de5315ef187834d8b77ccfdfd764cc1f04aaf9637228c4f0
Deleted: sha256:464a49ffb9c63559426f06c9fa8c334adc8a6cf43b75186f78154dd3a37912f2
Deleted: sha256:d2d27218c799da5732264d46461f9c12c746070a9d5a116f92804bea1c67460c
Deleted: sha256:a655cee601c1a7bbc77772c85690a7c290f51f38b2674dedff32aa89cbdd6c50
Deleted: sha256:ac19f2ec717b5455281b13d43a0da4e8751f9ed71ea780d8825dc9ebb7e1abcc
Deleted: sha256:7e45f6f328ea070a26974ceec1bbcbbea0c0f41e890a7f8fc3f1bafcbd05d397
Deleted: sha256:62da98477ef726430437dca541d83209c09857efba2167789aaa137b2f831191
Deleted: sha256:b7335be60baf107bc992b6e07a63ded5ef16ffebde5ae30971d30743cb554339
Deleted: sha256:13e67de16e1687451f700f17ef293c637a02e85048304ff4a1b580aada4ae32b
Deleted: sha256:41c78d861198c10e741bdd85a5a9dceaeabe0c891a0209b5a3ae544aeaf55f62
Deleted: sha256:e5f748f18fd5cce2702463a65c20529300677c5cc37ff77d1eac7b72607a4f01
Deleted: sha256:f8a8a709b891517f4e4bc49f33f5b97ae0003cc27f26ce5988d3509ad520105d
Deleted: sha256:0e05e97fb40377f1241697619b69818945f1c6bca135655e8c0cb28ed83c2940
Deleted: sha256:a58611fcce17499ba20a650786244fb1307c00b2a7fb6f202707591a061a5514
Deleted: sha256:38f256a0fb5ac0d0e209ef0c87f4a9899d46c2f1834db1bbb6be32bb5061bbf2
Deleted: sha256:4c0b744a547c95ab1bc3c3791f29233a2dc1ab2cdfa19d1a39dce540a9934188
Deleted: sha256:907a167b7d561cd5d22ea6643d9a7840a88d2af83cc20564e80202443a7569be
Deleted: sha256:ad9c6d566b59d2b1033fe574fe25e1bbf69bee1a52608140b9fe1ad85e77c8ed
Deleted: sha256:e1b47212f4a82f0c5324c1d13e89b41861294998864bbb5450c2b06c3b397a7d
Deleted: sha256:93e45e31086a143309bda55d66d0d8aa7e2ade536543f097daeb7e18d8938cf0
Deleted: sha256:400c4b3962d19be893856335ccd22330f9b19c69eb60366f6ac02c79d99dda48
Deleted: sha256:4ea375284256d3c9ed8ecf936649cae6bb59076dcbd8ea38522e05a1a64604a8
Deleted: sha256:32c658d0eecba3d86585297148cf5f257cdb14c329f86f71316497f415e83304
Deleted: sha256:ef51f03384d25377123879a65c033e465839f367208074e3f2099397ea042f5d
Deleted: sha256:c2bda8d9b71449287052a17cf7e00568ef871c2c488ef6325b1d490763062887
Deleted: sha256:ce2cee6ffcc070b5b0bb42a5dd7a5ef5fc08f37ff7d69197314adc50106ea364
Deleted: sha256:d8b7cccb2a148d0da69632eae2c538f0bba03ca2520420c894e77b84a37591bf
Deleted: sha256:5f6a2b267c87a043f8f03dc790023f6b8b048e0289b995cbaa54af9d2d6da948
Deleted: sha256:6f7ccebccce3d23e78c8d6dd200a911bdc650db91062b47a6d43dc28b3d51397
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b1c4ef917efdfba92474d982102c262dd7937991083b6bb72fb37353f3be1987].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1199112.
Stopping expansion service pid: 1199113.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 3s
232 actionable tasks: 161 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1412

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1412/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
2023/03/17 09:28:02 Job still running ...
2023/03/17 09:28:33 Job still running ...
2023/03/17 09:29:03 Job still running ...
2023/03/17 09:29:33 Job still running ...
2023/03/17 09:30:04 Job still running ...
2023/03/17 09:30:34 Job still running ...
2023/03/17 09:31:04 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-17_02_22_28-5040832660978972628 failed
--- FAIL: TestXLang_Partition (560.20s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3368.574s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679042133767722978
--- FAIL: TestBigQueryIO_BasicWriteRead (4.43s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33683 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ohKakyjndK" is_bounded:BOUNDED windowing_strategy_id:"w0@ohKakyjndK"}} windowing_strategies:{key:"w0@ohKakyjndK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ohKakyjndK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ohKakyjndK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ohKakyjndK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679042133767722978\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ohKakyjndK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33683 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ohKakyjndK" is_bounded:BOUNDED windowing_strategy_id:"w0@ohKakyjndK"}} windowing_strategies:{key:"w0@ohKakyjndK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ohKakyjndK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ohKakyjndK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ohKakyjndK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679042133767722978\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ohKakyjndK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00067ea00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00067ea00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001690c0?, 0xc0001162d0?}, {0x113b23e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc0006aac60, 0xf}, 0xc000545d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169060?, 0xc0001162d0?}, {0xc00051a300, 0x52}, {0x1?}, {0xc000545ea8, 0x2, 0x7f3884194800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0006aac60, 0xf}, {0xc00051a300, 0x52}, {0xebcb60, 0xc000136400})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004829c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004829c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.460s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-083458
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-083458
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3abcb09016c789907ca062bf10a7bfbe55e783285e3a4c1d0b950b477c80037f
Deleted: sha256:8c969886219308120834d64c393e036c34c1343379922123d7f4b99c170981f0
Deleted: sha256:d4431c0ace877099c26d0f398d05b5aa45c3e8f041cc56e0e8e2f1548b56fa00
Deleted: sha256:280e50dc36b58192bec97903c9feaf856be5d95c7fef76890f0d3b862169586a
Deleted: sha256:096eb72d41bf0767ed6200dfb13f14470c1fc1ea509d8629eaeb7401e3002084
Deleted: sha256:9515abdc0a6d7cc9069bf1dfc622ed9265801545d8d25aa90c45a90155f26480
Deleted: sha256:e1f768467549122ffce597c6c6caf2af84aaf9fd0d10dbeb53df006d57bb0f8f
Deleted: sha256:b2e474cf549f793b94b023c9611abfcacdc96ae76fc041577961c3bae63cccc5
Deleted: sha256:b5c10d3178a2c4bd1e006ad89e8c83fe3411da95927fdbe10b9bae3ff12db548
Deleted: sha256:c2babd6df39870dd9b2cc5ed49f79cfb9770dc7e719fffd3eb1da88cf2103aa2
Deleted: sha256:af63dabd4e03dd862b916c8018b278bbd036c82295e4d269abf721c489584883
Deleted: sha256:6e44f49095286ca0d12775c5a563c39bc34c587877cbffca9f4a938ecc53b790
Deleted: sha256:132cbf7dd21d5d0d43651ed00f28e92bd994d6debbd9be265b15f06ad7994bdf
Deleted: sha256:a6d847cd5871e4d01cc73683ad12688d97e64c8609218521d5a0e24ea4679844
Deleted: sha256:096da870c674e6364495ca9cde3412165f281c3587f2bfc64ee224c6e727579f
Deleted: sha256:3d093d513399de80f0508b944b05d7b6bd1535adeac5279e2f179f14e3d0fa33
Deleted: sha256:123d75d7ffea57453f7d249a3f779391a153b3255d1b305742611cbbc59654a3
Deleted: sha256:70e98e8fc36e3232ccaa6be202e1cc152d2ba6a664d253ce5e94ad0c9e08d62c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-083458
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3abcb09016c789907ca062bf10a7bfbe55e783285e3a4c1d0b950b477c80037f
  Associated tags:
 - 20230317-083458
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-083458
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-083458].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3abcb09016c789907ca062bf10a7bfbe55e783285e3a4c1d0b950b477c80037f].
$ rm -rf /tmp/tmp.sQt0JhKeoW
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317082043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6f2b75de9f4f11b4be94fbddc2a82593b040c268596c7c58f0a817809758e49].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317082043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010
Deleted: sha256:be618cc557eecde3d407afa49d24f40a75f27f9495353ac09884a81c1fd65ce5
Deleted: sha256:35e04c31fa75778cc5f72401da6e0161c62185c540754828d6e4c95dbdd67166
Deleted: sha256:43f33fd07f44324dc8a6c0ade04afd19ddf4fec1697f700d4ddb2de6bb00d2ae
Deleted: sha256:96c099a05fea8c541046ddaf8d8d5d0100a8047933d3ac9ee1273387d0377d92
Deleted: sha256:d17e9283980de22459b03bd015944753c4a5ee1defd7266f1b7ff3637ef02c6b
Deleted: sha256:4cfb31140fe960e4c4ac80482ef762c56b5f83ae18cd755347ae7898f5ce849b
Deleted: sha256:90abe539750082f03059a0d030934495f2862f441c1a8924c533cb60e9f0ed98
Deleted: sha256:440bda7a01a68b41a181a3e772cfbabbb1eef801bfe7850b4f66a63f753296fb
Deleted: sha256:8b2df8710d2276f48ded8191cc0f152e64f913c99d694dee3cf95bac79dbcb46
Deleted: sha256:1de2da8ccc4b4a57471fc428523162bc63a4e3020fec1f3f70a72bcf3f5022a5
Deleted: sha256:e30ca32bd04f65969f4a6435a16de4cb1032c9108917f2185b53408a5334c8ed
Deleted: sha256:9ab44c2b4e1a3d09a507ecf54524c31129fbf7a1a9f1aaed81b73002b6da93e9
Deleted: sha256:0af122b6937c0b61d97dfe9f6bc0d78e00aeb664ca1204bc67db9b9f993333ab
Deleted: sha256:0fd5fe187cd1cc6ed44b3bbec2c4831b26a3d71b6ffdcb5f517387f81edbffca
Deleted: sha256:0dcbde5487252ab9c020d7a821832cb1665a820adaea641c2958766acd043f09
Deleted: sha256:552f175ace83a32526e8835ad71d26d75a37aa979589f3792dfd62642fbe4197
Deleted: sha256:2f8818afb63c67c711ffb500779fc99c30fc244bc142edacdcfb98b8a7c57898
Deleted: sha256:3a62af3875d48691bedcef276408bdaae73ae31b094f0eb4ea83dee8b4163b1e
Deleted: sha256:6ca78a9ce44ca87b75630491c652051115903d4121c6b88c486abafd1658487e
Deleted: sha256:ec7fcd6f06f4bc7d71d230a395cfb59529a2a1d862abc6f0c869402bdb17336f
Deleted: sha256:46bc35280dfdbfec15d166835038c4e109c36654aaf70862adf3d9a9ecca37ad
Deleted: sha256:09fdc80fdf4676ffc81c257266026fc13844ff365f88d0c2db52a6c2c042c75d
Deleted: sha256:fe33c91fb10d5441d3a394845bae74200b3469ec307126ad211435bc1a906eae
Deleted: sha256:8530f6621f666a24cb7248be3b2b0db3cb2aa1e9f3fafcc1a4f9aa6f3cddcbf4
Deleted: sha256:40391f399537c8a62854fedd996df9abcd7fcf4b331c99717147cd7057e769f2
Deleted: sha256:ae860a796564a34ad757d2a3fa85bac95d5b76d3513535732b6dc816fea26a92
Deleted: sha256:27564f73206008f42de59de508a39ec2ff7de207e67c84eb6e095bba410d2fa1
Deleted: sha256:8256e66072e881ecbef6cb61b558904fea6141435eaeac39031b25c7c3f22834
Deleted: sha256:6e16cbc0d789c626ee8b75a8fbf5cd69cf51606be0c4ff374c43f30afae39391
Deleted: sha256:84189cfe9bb9e959a674a0f7dbf0ab9dc1288843a3dfd47d302371aee2e281be
Deleted: sha256:c372f2d83f2154d29afc09e7ec5f1a4faf4cfc2e279d169f81c7f40f69224bf2
Deleted: sha256:c9740249ff1b8b6d71925904993b491b823a3e489c5a45a4310f022e5a0e5e65
Deleted: sha256:254503d1f2091b069a04b16cc52a76aba735824a55ee5fc4740c123b5245dda5
Deleted: sha256:ae44e9d7bea6cdedc76a593b9d667fff7d4ae6a93c8eaaa224ac017e8cbc3e61
Deleted: sha256:8749860a4f27a6ca1127ada6f95f6bc6c632ab073f1463dee1d6d5cac44d4c7f
Deleted: sha256:405137cf10239f42aae15fa26deac2bb8c316fa36c0f943d4e45be089a14d94f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9526e55887ee5072a1adf3e87bab9ae84811b7f91fe9ecf89a000e68802cf010].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 918963.
Stopping expansion service pid: 918964.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 11m 26s
232 actionable tasks: 163 executed, 57 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1411

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1411/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317022038",
            "environmentId": "iRpLdYkQBNbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234"
      }
    ]
  },
  "name": "go-testxlang_partition-771",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/17 03:18:23 Submitted job: 2023-03-16_20_18_23-9808844694210132666
2023/03/17 03:18:23 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-16_20_18_23-9808844694210132666?project=apache-beam-testing
2023/03/17 03:18:23 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-16_20_18_23-9808844694210132666
2023/03/17 03:18:23 Job state: JOB_STATE_PENDING ...
2023/03/17 03:18:53 Job still running ...
2023/03/17 03:19:23 Job still running ...
2023/03/17 03:19:53 Job still running ...
2023/03/17 03:20:23 Job still running ...
2023/03/17 03:20:53 Job still running ...
2023/03/17 03:21:23 Job still running ...
2023/03/17 03:21:53 Job still running ...
2023/03/17 03:22:23 Job still running ...
2023/03/17 03:22:53 Job still running ...
2023/03/17 03:23:24 Job still running ...
2023/03/17 03:23:54 Job still running ...
2023/03/17 03:24:24 Job still running ...
2023/03/17 03:24:54 Job still running ...
2023/03/17 03:25:24 Job still running ...
2023/03/17 03:25:54 Job still running ...
2023/03/17 03:26:24 Job still running ...
2023/03/17 03:26:54 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-16_20_18_23-9808844694210132666 failed
--- FAIL: TestXLang_Partition (551.93s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3245.790s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679020402532314352
--- FAIL: TestBigQueryIO_BasicWriteRead (5.56s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39919 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mOzWzpsTAN" is_bounded:BOUNDED windowing_strategy_id:"w0@mOzWzpsTAN"}} windowing_strategies:{key:"w0@mOzWzpsTAN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mOzWzpsTAN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mOzWzpsTAN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mOzWzpsTAN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679020402532314352\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mOzWzpsTAN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39919 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mOzWzpsTAN" is_bounded:BOUNDED windowing_strategy_id:"w0@mOzWzpsTAN"}} windowing_strategies:{key:"w0@mOzWzpsTAN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mOzWzpsTAN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mOzWzpsTAN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mOzWzpsTAN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1679020402532314352\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mOzWzpsTAN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:232)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:197)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc0006926c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc0006926c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004080c0?, 0xc0006ae050?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000122a00, 0xf}, 0xc0005a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000408020?, 0xc0006ae050?}, {0xc000134300, 0x52}, {0x1?}, {0xc0005a9ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122a00, 0xf}, {0xc000134300, 0x52}, {0xebcb60, 0xc00040c008})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102b60, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.588s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d360251394ae46ca0ea1db023495b01f1949b635db320d0ffa05a79b29121cd
Deleted: sha256:d7443ea1e1caccd76d1165a51c6e08e9e657217c7dbaafef64052bee9011892c
Deleted: sha256:065044e9e8421f9d087b23b4a2bfaa1b9d89aac2649a93832f99fb597292edf1
Deleted: sha256:ad0a578894bb95f5eeb9279da49e2b5788e9305d4c38d4487a52306853aab751
Deleted: sha256:df47d334d812a86a15ccccca1659ab3905c6ed49b8a45dc4eaeeadae96d499b3
Deleted: sha256:2924774fb13cbf51fbdb1b7f3ae14a9f8a580093c74a65d05138fc9752a22837
Deleted: sha256:ed3109181b9cda174b1196f814c398004ea85fc61b861809f22149d3c6a1fad1
Deleted: sha256:8ba94b58fcc35158d1172165fda034397827f2ddd5bca8370b5ebe9cfa1a10b0
Deleted: sha256:0085e532de30d187cb6db245921da6e5013a7c876567ece5e152ca923c7bfda8
Deleted: sha256:2bf60aa770226b57ae4304e25bf0d8c7b50b88b3e54894adefd83433d6deee58
Deleted: sha256:87595d9ae2dc851498fbac5bb601ea21086b4c5cc128b804b6eb1295c065baf4
Deleted: sha256:980610cf7cd4dd660a33f027146aeb6f72c4783097e34ebf99415e7765b02e44
Deleted: sha256:e1c81c07d8d46c9d97f673e05f257eb93f33d258ad2ece804f9ec43f718686de
Deleted: sha256:e9598850e19dc17bb1dbd99d7c49a655ff405c5e8d7287e7312c9097711c559c
Deleted: sha256:2ec9b2c83fb4f86c644dcca58aead91867bed6ab1d99de59e3d7515452599e45
Deleted: sha256:91b13adaaa3233c41df00a8891c2fe63e8ac17680093b191908dde9e17969286
Deleted: sha256:f439362a1813b692af6d765100e151fe12edc08c22f69a9e243ca05236c3640b
Deleted: sha256:e2ca4f3586b0d09b94bc2c94f657e35be2e0c446e57ece5ac50de3195b5a73ef
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d360251394ae46ca0ea1db023495b01f1949b635db320d0ffa05a79b29121cd
  Associated tags:
 - 20230317-023234
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230317-023234].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d360251394ae46ca0ea1db023495b01f1949b635db320d0ffa05a79b29121cd].
$ rm -rf /tmp/tmp.zhDYST0rkt
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317022038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230317022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3b33de8d09ee7e39550f7923d303a6d33844ca0eaa8c1be174c77d9615a903f5].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317022038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230317022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9a448e23ad8fdd0e01ea13675658d1208d0ec22c6b8a6fbcb345e39929f5f99].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1943623.
Stopping expansion service pid: 1943624.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 13s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1410

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1410/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316202030",
            "environmentId": "IJSXhRMwCtbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216"
      }
    ]
  },
  "name": "go-testxlang_partition-928",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/16 21:18:26 Submitted job: 2023-03-16_14_18_25-11637032884258629302
2023/03/16 21:18:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-16_14_18_25-11637032884258629302?project=apache-beam-testing
2023/03/16 21:18:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-16_14_18_25-11637032884258629302
2023/03/16 21:18:26 Job state: JOB_STATE_PENDING ...
2023/03/16 21:18:56 Job still running ...
2023/03/16 21:19:26 Job still running ...
2023/03/16 21:19:56 Job still running ...
2023/03/16 21:20:26 Job still running ...
2023/03/16 21:20:56 Job still running ...
2023/03/16 21:21:26 Job still running ...
2023/03/16 21:21:56 Job still running ...
2023/03/16 21:22:26 Job still running ...
2023/03/16 21:22:56 Job still running ...
2023/03/16 21:23:26 Job still running ...
2023/03/16 21:23:56 Job still running ...
2023/03/16 21:24:26 Job still running ...
2023/03/16 21:24:56 Job still running ...
2023/03/16 21:25:27 Job still running ...
2023/03/16 21:25:57 Job still running ...
2023/03/16 21:26:27 Job still running ...
2023/03/16 21:26:57 Job still running ...
2023/03/16 21:27:27 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-16_14_18_25-11637032884258629302 failed
--- FAIL: TestXLang_Partition (581.81s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3303.970s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678998777260841959
--- FAIL: TestBigQueryIO_BasicWriteRead (4.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33147 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RYXfXBHRkS" is_bounded:BOUNDED windowing_strategy_id:"w0@RYXfXBHRkS"}} windowing_strategies:{key:"w0@RYXfXBHRkS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RYXfXBHRkS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RYXfXBHRkS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RYXfXBHRkS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678998777260841959\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RYXfXBHRkS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33147 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RYXfXBHRkS" is_bounded:BOUNDED windowing_strategy_id:"w0@RYXfXBHRkS"}} windowing_strategies:{key:"w0@RYXfXBHRkS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RYXfXBHRkS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RYXfXBHRkS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RYXfXBHRkS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678998777260841959\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RYXfXBHRkS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00057e940})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00057e940})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7a80?, 0xc000417720?}, {0x113b23e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc0003fece0, 0xf}, 0xc0004d3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7a20?, 0xc000417720?}, {0xc0004a4360, 0x52}, {0x1?}, {0xc0004d3ea8, 0x2, 0x7f981867b088?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fece0, 0xf}, {0xc0004a4360, 0x52}, {0xebcb60, 0xc0003ffff0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003e96c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003e96c0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.880s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.031s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.028s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09047a2c447d3f7d766024c2bd0fc80ecf586be0f6a477bc79062de20fb846e2
Deleted: sha256:e6c95d5926b4ae3bd061d0f16416a302c015ea4b19203f3e395e599ebadd217f
Deleted: sha256:373ea6a22db5c2eecfb5d59b8f29b650aa4a2011db7e768e26064308a011bd6c
Deleted: sha256:119bdf408af0e1e6c3ac9fa69b975eb047dca7c48bf087ae405eeb2039539a7c
Deleted: sha256:6cc12365a66c0c9514a6f9ab063c3e948414cd0170417faa7d5c941ec67d2d12
Deleted: sha256:47c23b747a79a6c6773077c473af7f4b352da9b724c3ac472413cc8f3f1c2231
Deleted: sha256:0d5de8723e01a1f062ad7791fe7ab2c38144e07ecbd661c55d7382a7a7cc26de
Deleted: sha256:54fbbf74c448a29893d4d1a590940fdbc863c3f72b85a6251d71086dac7e570d
Deleted: sha256:96e9f71d5b57c890f6cda381630c10bdd606def8b7a3befc78089c941c47ff93
Deleted: sha256:5ae6c8ab0068dda7a37424165edafdb51a099ec3e83866c368b617d85345d22c
Deleted: sha256:ff85a997a8b8036882a31426c033d8c7c38f71371ece7c82d566fcf30993e80f
Deleted: sha256:8a628867d1c9fbce7bb63aa06284f56d7a4cc1341b56b4caa0872f9e967b964a
Deleted: sha256:18ecd5f7604b77aba0b9f6d33dd3cd8ec80851225967eb5c02645d8cd3d6b40e
Deleted: sha256:9a47ac82cc2afc3e1b4a2dde7bc6cc4df4fde506c51f37cba0411bb27b943308
Deleted: sha256:8030358b7e628d9483a69572aa0ad11392b8161932083215188533ad85806d58
Deleted: sha256:34cde3dcb2528b7ce867ceb86f6538c6416db1942f477b05e0406156bd9c5e31
Deleted: sha256:9d20f52de2f2da16266f184e622ff09ebadee12127176d399417f0282295c80e
Deleted: sha256:da6c7e10f4d7bb4b0e142532c90de3e5ba45d8f073c613f522c15994b05df90d
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09047a2c447d3f7d766024c2bd0fc80ecf586be0f6a477bc79062de20fb846e2
  Associated tags:
 - 20230316-203216
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-203216].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09047a2c447d3f7d766024c2bd0fc80ecf586be0f6a477bc79062de20fb846e2].
$ rm -rf /tmp/tmp.zbAhgNStPx
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1cb082292d4b8723ea5de5a17732c6671cd46bf5293984fa77732df67361edb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:21a0e41994fa70a535dc7ab13619357d283ec52afc0fcdef967d8628f802aed6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 376789.
Stopping expansion service pid: 376790.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 1s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1409

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1409/display/redirect?page=changes>

Changes:

[noreply] Bump grpcio-tools from 1.37.0 to 1.51.3 in /sdks/python (#25585)


------------------------------------------
[...truncated 1.01 MB...]
2023/03/16 15:21:59 Job still running ...
2023/03/16 15:22:29 Job still running ...
2023/03/16 15:23:00 Job still running ...
2023/03/16 15:23:30 Job still running ...
2023/03/16 15:24:00 Job still running ...
2023/03/16 15:24:30 Job still running ...
2023/03/16 15:25:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-16_08_16_28-15866721582068811796 failed
--- FAIL: TestXLang_Partition (553.38s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3161.933s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678977171625259666
--- FAIL: TestBigQueryIO_BasicWriteRead (4.60s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36459 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@UrzvqwAQMl" is_bounded:BOUNDED windowing_strategy_id:"w0@UrzvqwAQMl"}} windowing_strategies:{key:"w0@UrzvqwAQMl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@UrzvqwAQMl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@UrzvqwAQMl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@UrzvqwAQMl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678977171625259666\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"UrzvqwAQMl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36459 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@UrzvqwAQMl" is_bounded:BOUNDED windowing_strategy_id:"w0@UrzvqwAQMl"}} windowing_strategies:{key:"w0@UrzvqwAQMl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@UrzvqwAQMl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@UrzvqwAQMl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@UrzvqwAQMl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678977171625259666\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"UrzvqwAQMl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc00063e800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc00063e800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040e8e0?, 0xc000138230?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc0001316e0, 0xf}, 0xc00065bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040e880?, 0xc000138230?}, {0xc00004c600, 0x52}, {0x1?}, {0xc00065bea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001316e0, 0xf}, {0xc00004c600, 0x52}, {0xebcb60, 0xc0004101f8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582d00, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.636s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-143215
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-143215
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fd4b8d4a03891a80822b526feec7af0e09b814c04b0013156bce3cc8a2faf34c
Deleted: sha256:a1d7835330d541bc2949595598da5fbb144fc1acab454df67fa0a0d63286ff4a
Deleted: sha256:49ecd9bdc83ff5a770a5deba204b280c9c7f0e6c54c284662993c41d8b5145e8
Deleted: sha256:f6e03a5e16ed2489e78d7f8b7862a834880665ffbdf44004a841b29073d6c41e
Deleted: sha256:645ae1b21ad8a26df45852d9979c710d87718cbbc950c9240096a43aa04aa9c5
Deleted: sha256:b8d7542265475f4b03e2d2695f94ca3ab98cb79043c8d733a6eb9bc5eb33087b
Deleted: sha256:2f3978aae78b4b2da435b6ee6625611913418c41d5e4d3dfef10e18ce001d310
Deleted: sha256:282945d81fa11672ac8007dd3f31860f05adf897cb6a5e5b51ef4b50dc3864f7
Deleted: sha256:2a39099e5863385a739c4874ae197deed769c229e8590135f1a811234ac06358
Deleted: sha256:18348bee7c0e5c3ec104ccb555625554b8699d575992f91ea5f5da9edae52877
Deleted: sha256:8b3f713b6bdfcedb0fe59f344b9957bb5f2ab49778a5985444757ae7748e16c6
Deleted: sha256:e92b8dd613b7841f55f15caa50a38843116beb8a2d93a3c29045a431ec6887a5
Deleted: sha256:1ff737f61d385a7c97e9d4c9a58f3baaa1f2797f44e9df40b68228f436b7d298
Deleted: sha256:6fdff1a7f77d33ac6982cf668cef381ca123a5bde76ef0c353c1792d097e2d87
Deleted: sha256:059e68d14868c9e63a7387ac872f58199f344e608ccb541c6b6348e20f3bff4f
Deleted: sha256:3d65b523491ae3332171031b2baba3929ebb190250d8707afb2ff904d245f7db
Deleted: sha256:a99c9d25e248585421b1acf2e44a50d463f9e7b6399c94ddc77a114080801ae9
Deleted: sha256:d53e85d796cb5e8497375ef3fcbf18859be0e339383519295e448a67d95ff11a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-143215
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fd4b8d4a03891a80822b526feec7af0e09b814c04b0013156bce3cc8a2faf34c
  Associated tags:
 - 20230316-143215
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-143215
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-143215].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fd4b8d4a03891a80822b526feec7af0e09b814c04b0013156bce3cc8a2faf34c].
$ rm -rf /tmp/tmp.DWKPL6FOKr
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316142031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316142031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316142031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9a1afc93a245dd9d1dfc9835d4002faa14d6d02c7e91aaf4645e45382f900b81].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316142031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b
Deleted: sha256:69640c9896d697d84ac66948438974c2048493c459369db5efde1df9b358cecd
Deleted: sha256:81df1173f4623e2a81d8db7fa3c6e1f8c32a75949414e63312e19c120030f351
Deleted: sha256:6af73e83d1d220f3920184c6b28211bee0ee65de66280a6d1979f56b6d23f1e7
Deleted: sha256:c71004f4f2ebe3468a88ab9bf0f0197118607c396f8ba6dfb146659869c636fe
Deleted: sha256:d48871cdc7b555186b6f50cd2d82bfbcb7080f272bb7ab9da394160d84e2536b
Deleted: sha256:00967bb22e25cda57a2925f42a9e81f005cca049174330a95f3436b92d82d765
Deleted: sha256:3af7ab54cf4c9708978788a0a86f5cde1f356ba66b061f4ccfd91c588292de05
Deleted: sha256:3f96866b217f92c77d6929bebee9868a0c0995379aa6e50af27e232dea8ef14b
Deleted: sha256:e825edf1efb9fea0db0cb49cc592315e70c685f4f8921771fdb6f7574d14ea17
Deleted: sha256:e455547c308eb1acb4140f42186098b5461f8f1a9eefc210835466a7c6c541fb
Deleted: sha256:ca3e1c683153fde6ed1acb9627903f5fb6275ebb890e5f506ade6295007f052b
Deleted: sha256:16e1b923c558a1ed632bbadc459901017feb9a6bd631306371b5e85ce85e94a4
Deleted: sha256:ad377d11ddba98aee8359a2b5bbed2be1bc52a423222ae7ac1c7fa5cbeb4bfce
Deleted: sha256:a39d0d4c10808fdbc4b9b5f36d6af0ef32ee8a306ee58b05c8e07bce1b849f09
Deleted: sha256:59d2d0d95b7c6e113ae27a7ef77eca1bb95378139c4313ec9745fd38c9e6f973
Deleted: sha256:4d8202fae80a0a50453a559972bb6e2f0a2aef528bf49d1effded753e9ee8644
Deleted: sha256:cf982ea7047d6ae1d7c266b5bc0ba0d6083467e3d6f6c19fceff5a7861975d70
Deleted: sha256:8a4f62b8039b487eb34715e28da6fb3a4bea789ea56a11227e49f4c35bcab75e
Deleted: sha256:af6f1ab5dc695571d2072442887f087fe65eb7454a93e8dfaa85c23332bbe43e
Deleted: sha256:d01edd65728b4a2543b40f7d7b73694ff1548a255eb1699ebf576a7af6332090
Deleted: sha256:c254d88cab13b39b880e4767a1b87ad5367991534bb1a422c59db5efe92ae54d
Deleted: sha256:c8b7748d1d47534365b38cdb8c0d1cbd88e33591c73ade272f8aee3803b863e5
Deleted: sha256:5603e2bafdf838e40155b560da9a1a718a6b244d6e29534977f34ea1f682be7d
Deleted: sha256:0295aa5f11aee5b7a5a618a54f2e0040dee67f3c724b2c48287f58f42ef06437
Deleted: sha256:ce8ac0f92ee43baadcec4494d9c90e186011e2f95c2cdb52af82ce62109276f2
Deleted: sha256:2247161aac4b8da95b54758fdfaad6f08e0947dd82d18a75772d1ed12ad57108
Deleted: sha256:d5d146640a8d3a1bcabdc3bf835d12af6ffca3fce4fe8748d2ecb72e1363e4ab
Deleted: sha256:667f50e3bbfc1d38c86f1a4c99e066630a3234ac20823f262942476810769b1d
Deleted: sha256:708b3ac840933a24358383b313c997952e818e39ed7a97d4a17433968e38ce01
Deleted: sha256:f465e589433ae1139eca36e793c440e67ea21cbd04d346953f23d7ba18c0bb0d
Deleted: sha256:2af0c01e58d06858cccc60d67713eb9d379071a57ef0e93d5bf7d81c543a0806
Deleted: sha256:80ab328ac4542443cf2117c85bbd0227be0b8295d26147d12ff1806565ed88f9
Deleted: sha256:ca1bcc4e903b75dcd3f97164b25b188e5e0b66d681a0883b1229d69d1b9c41c8
Deleted: sha256:ee05bfbe424f731cc0474250cf6f3e879ea9b88e46b1481db8cf9f041dc4b6d6
Deleted: sha256:80f1cd64d1bf90b14c646700f23c27ff2fd84f93142f948e333b1bbcf161b1a5
Deleted: sha256:cb713c3f4d4be42166793aefc058a4b06d43a809da22b2eb9f1bdf7bf185b8b3
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316142031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316142031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:594a73633190641f1e8fc72a9d0950cbddfcb78c65844420ebcb4b9356d51d5b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3838748.
Stopping expansion service pid: 3838749.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 25s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1408

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1408/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316082033",
            "environmentId": "FvbenjtcVIbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201"
      }
    ]
  },
  "name": "go-testxlang_partition-369",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/16 09:16:37 Submitted job: 2023-03-16_02_16_36-8298187309890712891
2023/03/16 09:16:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-16_02_16_36-8298187309890712891?project=apache-beam-testing
2023/03/16 09:16:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-16_02_16_36-8298187309890712891
2023/03/16 09:16:37 Job state: JOB_STATE_PENDING ...
2023/03/16 09:17:07 Job still running ...
2023/03/16 09:17:37 Job still running ...
2023/03/16 09:18:07 Job still running ...
2023/03/16 09:18:37 Job still running ...
2023/03/16 09:19:07 Job still running ...
2023/03/16 09:19:37 Job still running ...
2023/03/16 09:20:07 Job still running ...
2023/03/16 09:20:37 Job still running ...
2023/03/16 09:21:07 Job still running ...
2023/03/16 09:21:37 Job still running ...
2023/03/16 09:22:07 Job still running ...
2023/03/16 09:22:37 Job still running ...
2023/03/16 09:23:07 Job still running ...
2023/03/16 09:23:37 Job still running ...
2023/03/16 09:24:07 Job still running ...
2023/03/16 09:24:37 Job still running ...
2023/03/16 09:25:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-16_02_16_36-8298187309890712891 failed
--- FAIL: TestXLang_Partition (550.94s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3183.518s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678955557651341979
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41701 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@IsoZyZHfcv" is_bounded:BOUNDED windowing_strategy_id:"w0@IsoZyZHfcv"}} windowing_strategies:{key:"w0@IsoZyZHfcv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@IsoZyZHfcv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@IsoZyZHfcv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@IsoZyZHfcv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678955557651341979\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"IsoZyZHfcv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41701 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@IsoZyZHfcv" is_bounded:BOUNDED windowing_strategy_id:"w0@IsoZyZHfcv"}} windowing_strategies:{key:"w0@IsoZyZHfcv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@IsoZyZHfcv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@IsoZyZHfcv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@IsoZyZHfcv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678955557651341979\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"IsoZyZHfcv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000714cc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000714cc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00011a8a0?, 0xc0000b8280?}, {0x113b23e, 0x39}, {0xc0000ee0c0?, 0xa9e920?, 0x1?}, {0xc0000436e0, 0xf}, 0xc0005cbd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00011a840?, 0xc0000b8280?}, {0xc00059a360, 0x52}, {0x1?}, {0xc0005cbea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0000436e0, 0xf}, {0xc00059a360, 0x52}, {0xebcb60, 0xc000512158})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003eb520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003eb520, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.419s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87631c57f26565f96870ce79cefbd015b5775251d3fd3a3a16a78357f7baf2e0
Deleted: sha256:98a0f4870ced927e8530dafb49455c6d445c2cd4bc7916b390a4d5f23f2ae3bf
Deleted: sha256:e748d1d7746c77bedcd34f128b863824f8d0f60dcd00c881967146b51b3d7b10
Deleted: sha256:2272c2140e7674947553a2443f83fd479be663b5a28d1de67375b9001fa927dc
Deleted: sha256:70dfbaa0deec47bc6928f9e3b09162ae70f1fbb977b55c920b48d851cf82663f
Deleted: sha256:059c7979a03ee8f135199ea1979593d66fafa9da687197df91fc16935a8334e1
Deleted: sha256:0ab6ccd4db3abd2ade2f52a97bc1ab3d7115051be7850423cc3ad007f090addb
Deleted: sha256:a1efd9f24e3d502f8b02a1678be064ece498ccce40f32402e84ad5ba04006249
Deleted: sha256:b44baec6de006d951cc72317d9ad6f8dc3e62900b8be5da2b8482007bb193aad
Deleted: sha256:65197b4d01907504c13e1b3e1aa93716a11655d135017f9b93f500136ab2428f
Deleted: sha256:c371bedb19f3188278bf06cb4e1bbf8063f97cb544a869dcf0729c880949d776
Deleted: sha256:17e301ebe3770223b0d7dd6999e0cffd42e74297f7ab6e9abfa9c9f1cc9e4043
Deleted: sha256:2082e106c1c2a499235addafeffa3ad33abbf433512560552a9ef8e34e752f33
Deleted: sha256:32a14311a32ecf0f7769efc5d80529a81e2d931654de1cee127366ce5fc338cc
Deleted: sha256:2207623becbf8f43a917b5d430adf1d2cf49f7df1252b2cad85c93d1acdfb25d
Deleted: sha256:9f22747e55c642490864296dd43bd8f965f1735216c1d430132cd7b7bf864bd6
Deleted: sha256:b431b57204521f8d75ed7a017f5424f59a892053ba9abfdbf34e6a9bd34381e5
Deleted: sha256:a2a922b1bf21b494bd35084327595fca960bccf62d76e01cfc14ae3810762fb2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87631c57f26565f96870ce79cefbd015b5775251d3fd3a3a16a78357f7baf2e0
  Associated tags:
 - 20230316-083201
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-083201].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87631c57f26565f96870ce79cefbd015b5775251d3fd3a3a16a78357f7baf2e0].
$ rm -rf /tmp/tmp.Njg8Ay7kZ4
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316082033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316082033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316082033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3f43bd7b4cdd3bc35414139ce0c9341fed637e34adb5eabbabc55c999e771c73].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316082033
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316082033]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316082033] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:203bd822adf2d7dff241bdf9932e4994561c945ba3e7c88d87988bf937688647].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3696260.
Stopping expansion service pid: 3696261.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 34s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1407

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1407/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-023205",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316022042",
            "environmentId": "MFtYhrtcPobeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-023205"
      }
    ]
  },
  "name": "go-testxlang_partition-26",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/16 03:16:06 Submitted job: 2023-03-15_20_16_06-1176376381168351087
2023/03/16 03:16:06 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-15_20_16_06-1176376381168351087?project=apache-beam-testing
2023/03/16 03:16:06 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-15_20_16_06-1176376381168351087
2023/03/16 03:16:06 Job state: JOB_STATE_PENDING ...
2023/03/16 03:16:36 Job still running ...
2023/03/16 03:17:06 Job still running ...
2023/03/16 03:17:37 Job still running ...
2023/03/16 03:18:07 Job still running ...
2023/03/16 03:18:37 Job still running ...
2023/03/16 03:19:07 Job still running ...
2023/03/16 03:19:37 Job still running ...
2023/03/16 03:20:07 Job still running ...
2023/03/16 03:20:37 Job still running ...
2023/03/16 03:21:07 Job still running ...
2023/03/16 03:21:37 Job still running ...
2023/03/16 03:22:07 Job still running ...
2023/03/16 03:22:37 Job still running ...
2023/03/16 03:23:07 Job still running ...
2023/03/16 03:23:37 Job still running ...
2023/03/16 03:24:07 Job still running ...
2023/03/16 03:24:37 Job still running ...
2023/03/16 03:25:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-15_20_16_06-1176376381168351087 failed
--- FAIL: TestXLang_Partition (580.76s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3179.107s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678933962165347813
--- FAIL: TestBigQueryIO_BasicWriteRead (4.56s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40023 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@JnOEcNJQYu" is_bounded:BOUNDED windowing_strategy_id:"w0@JnOEcNJQYu"}} windowing_strategies:{key:"w0@JnOEcNJQYu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@JnOEcNJQYu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@JnOEcNJQYu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@JnOEcNJQYu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678933962165347813\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"JnOEcNJQYu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40023 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@JnOEcNJQYu" is_bounded:BOUNDED windowing_strategy_id:"w0@JnOEcNJQYu"}} windowing_strategies:{key:"w0@JnOEcNJQYu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@JnOEcNJQYu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@JnOEcNJQYu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@JnOEcNJQYu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678933962165347813\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"JnOEcNJQYu"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000551280})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000551280})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169920?, 0xc0001399a0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000554c80, 0xf}, 0xc0000f3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001698c0?, 0xc0001399a0?}, {0xc00010e8a0, 0x52}, {0x1?}, {0xc0000f3ea8, 0x2, 0x7f28c09ee2b0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000554c80, 0xf}, {0xc00010e8a0, 0x52}, {0xebcb60, 0xc000555f90})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001bb1e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001bb1e0, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.593s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c763298c2f7aa4b178c4b7d24cf5719b4174acad8c3ed47ad42b3a9274f22678
  Associated tags:
 - 20230316-023205
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-023205
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230316-023205].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c763298c2f7aa4b178c4b7d24cf5719b4174acad8c3ed47ad42b3a9274f22678].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:238e684f678f38e093582756119a0a98d4c5c68d0b46bdbe178de63848fb9277]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230316022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:238e684f678f38e093582756119a0a98d4c5c68d0b46bdbe178de63848fb9277])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:238e684f678f38e093582756119a0a98d4c5c68d0b46bdbe178de63848fb9277
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:238e684f678f38e093582756119a0a98d4c5c68d0b46bdbe178de63848fb9277].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3c79b4cb43fb235f49d3f743fb11e3f0e020e3ffdfbc36123a555982f0b0bb1e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230316022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3c79b4cb43fb235f49d3f743fb11e3f0e020e3ffdfbc36123a555982f0b0bb1e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3c79b4cb43fb235f49d3f743fb11e3f0e020e3ffdfbc36123a555982f0b0bb1e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3c79b4cb43fb235f49d3f743fb11e3f0e020e3ffdfbc36123a555982f0b0bb1e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 21s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1406

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1406/display/redirect?page=changes>

Changes:

[noreply] Update google-cloud-recommendations-ai requirement in /sdks/python


------------------------------------------
[...truncated 571.85 KB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315202031",
            "environmentId": "qUQxzTtkDybeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-203246",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-203246"
      }
    ]
  },
  "name": "go-testxlang_partition-139",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/15 21:18:23 Submitted job: 2023-03-15_14_18_22-16004047520289676750
2023/03/15 21:18:23 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-15_14_18_22-16004047520289676750?project=apache-beam-testing
2023/03/15 21:18:23 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-15_14_18_22-16004047520289676750
2023/03/15 21:18:23 Job state: JOB_STATE_PENDING ...
2023/03/15 21:18:53 Job still running ...
2023/03/15 21:19:23 Job still running ...
2023/03/15 21:19:53 Job still running ...
2023/03/15 21:20:23 Job still running ...
2023/03/15 21:20:53 Job still running ...
2023/03/15 21:21:23 Job still running ...
2023/03/15 21:21:53 Job still running ...
2023/03/15 21:22:23 Job still running ...
2023/03/15 21:22:53 Job still running ...
2023/03/15 21:23:23 Job still running ...
2023/03/15 21:23:53 Job still running ...
2023/03/15 21:24:23 Job still running ...
2023/03/15 21:24:53 Job still running ...
2023/03/15 21:25:23 Job still running ...
2023/03/15 21:25:54 Job still running ...
2023/03/15 21:26:24 Job still running ...
2023/03/15 21:26:54 Job still running ...
2023/03/15 21:27:24 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-15_14_18_22-16004047520289676750 failed
--- FAIL: TestXLang_Partition (580.41s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3270.722s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678912412511497004
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40797 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@uYDEglNHVj" is_bounded:BOUNDED windowing_strategy_id:"w0@uYDEglNHVj"}} windowing_strategies:{key:"w0@uYDEglNHVj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@uYDEglNHVj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@uYDEglNHVj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@uYDEglNHVj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678912412511497004\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"uYDEglNHVj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40797 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@uYDEglNHVj" is_bounded:BOUNDED windowing_strategy_id:"w0@uYDEglNHVj"}} windowing_strategies:{key:"w0@uYDEglNHVj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@uYDEglNHVj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@uYDEglNHVj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@uYDEglNHVj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678912412511497004\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"uYDEglNHVj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6ef60, 0xc000487bc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef60, 0xc000487bc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040a2e0?, 0xc0000ba0a0?}, {0x113b23e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000131680, 0xf}, 0xc0000d9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040a280?, 0xc0000ba0a0?}, {0xc000568360, 0x52}, {0x1?}, {0xc0000d9ea8, 0x2, 0xe7b820?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131680, 0xf}, {0xc000568360, 0x52}, {0xebcb60, 0xc000042158})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000d2b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000d2b60, 0x116d128)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.434s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9203096036eba7a15d2d2d51177f83b6a11ea2bddc9cc7da87cc4fa4491ac29e
  Associated tags:
 - 20230315-203246
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-203246
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-203246].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9203096036eba7a15d2d2d51177f83b6a11ea2bddc9cc7da87cc4fa4491ac29e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0445e7070b4ef193f086fa9c88bccf837da78f22feafbd3b19058ab2bbfae956]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0445e7070b4ef193f086fa9c88bccf837da78f22feafbd3b19058ab2bbfae956])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0445e7070b4ef193f086fa9c88bccf837da78f22feafbd3b19058ab2bbfae956
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0445e7070b4ef193f086fa9c88bccf837da78f22feafbd3b19058ab2bbfae956].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fea546c05ebd478eabae71b5ae85fa86b144e92130373ad3ba7360de403ac801]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fea546c05ebd478eabae71b5ae85fa86b144e92130373ad3ba7360de403ac801])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fea546c05ebd478eabae71b5ae85fa86b144e92130373ad3ba7360de403ac801
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fea546c05ebd478eabae71b5ae85fa86b144e92130373ad3ba7360de403ac801].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 50s
232 actionable tasks: 161 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1405

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1405/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315142030",
            "environmentId": "xcSgvysohrbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230"
      }
    ]
  },
  "name": "go-testxlang_partition-715",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/15 15:15:42 Submitted job: 2023-03-15_08_15_41-10715708166177094433
2023/03/15 15:15:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-15_08_15_41-10715708166177094433?project=apache-beam-testing
2023/03/15 15:15:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-15_08_15_41-10715708166177094433
2023/03/15 15:15:42 Job state: JOB_STATE_PENDING ...
2023/03/15 15:16:12 Job still running ...
2023/03/15 15:16:42 Job still running ...
2023/03/15 15:17:12 Job still running ...
2023/03/15 15:17:42 Job still running ...
2023/03/15 15:18:12 Job still running ...
2023/03/15 15:18:42 Job still running ...
2023/03/15 15:19:12 Job still running ...
2023/03/15 15:19:42 Job still running ...
2023/03/15 15:20:12 Job still running ...
2023/03/15 15:20:42 Job still running ...
2023/03/15 15:21:12 Job still running ...
2023/03/15 15:21:42 Job still running ...
2023/03/15 15:22:12 Job still running ...
2023/03/15 15:22:43 Job still running ...
2023/03/15 15:23:13 Job still running ...
2023/03/15 15:23:43 Job still running ...
2023/03/15 15:24:13 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-15_08_15_41-10715708166177094433 failed
--- FAIL: TestXLang_Partition (551.47s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3096.434s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678890796972378507
--- FAIL: TestBigQueryIO_BasicWriteRead (5.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38585 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@CoiKlAfWuM" is_bounded:BOUNDED windowing_strategy_id:"w0@CoiKlAfWuM"}} windowing_strategies:{key:"w0@CoiKlAfWuM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@CoiKlAfWuM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@CoiKlAfWuM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@CoiKlAfWuM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678890796972378507\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"CoiKlAfWuM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38585 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@CoiKlAfWuM" is_bounded:BOUNDED windowing_strategy_id:"w0@CoiKlAfWuM"}} windowing_strategies:{key:"w0@CoiKlAfWuM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@CoiKlAfWuM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@CoiKlAfWuM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@CoiKlAfWuM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678890796972378507\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"CoiKlAfWuM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 30 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000490d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000490d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6c00?, 0xc000139ae0?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc00032cd50, 0xf}, 0xc00056bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6ba0?, 0xc000139ae0?}, {0xc00010e720, 0x52}, {0x1?}, {0xc00056bea8, 0x2, 0x7feeea54c998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00032cd50, 0xf}, {0xc00010e720, 0x52}, {0xebcb40, 0xc000130c80})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005829c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005829c0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.245s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a7856ce2458289f29cb14ce77071d0b0bf067a1c2e6c1500c9ffaef2684944b3
Deleted: sha256:16803f77b957fca9ec933c29248945c611b88cdbac1ec9aae763d49a1fccacec
Deleted: sha256:73c5721c14ab24b6dec9cbd4bffa4338c880037d153cb900776a5cb850ccbf1a
Deleted: sha256:a108abed9c2661e1889a7369f2a4771c4204d45d96944de69ae602966d07098e
Deleted: sha256:42981de704b6ee815871edcce1658d0d9daae4953553dd228de6bb5d90a0f10a
Deleted: sha256:311d6d2796042c7eca6ccfadc4d994fe31e8be48b2e926b9ba583b5ab09d86d9
Deleted: sha256:dfc9e3c9b80cfcda201c24325b852bd38a6f671751f3ee29a2107a2dd480410a
Deleted: sha256:b91d9758bbfe521a398014b368b4836e4f8469245428b148a92c3f70b57e0ec7
Deleted: sha256:0f473e84b9733d3a0eaf6162d1a28dbc2fb74cc287cacdbd61db495f266b7616
Deleted: sha256:42d8ec91397a08943dc6a9a243b09d3235064189d39ccab316ba8ef1a6e77d4c
Deleted: sha256:4f547f70b7f0816352102b91cb649f1b28d63cb42b65a405934590f35a9f75cf
Deleted: sha256:b54e9f892e3aeae56dfd24bf50749a6e9ce7be341bedb7a3e346c89c4f428859
Deleted: sha256:15e4e4107673a69647664f8957b3a54d109679df5c1d019e2c1b02ac2764809e
Deleted: sha256:ec6dd8732b260f9ec7e4853db7008ad7c4a28fadcaffc99e38e39297f8e265cf
Deleted: sha256:c6542193312e75a3dee7632f705e0ceac0f6ba0554b86d847616031e1109a452
Deleted: sha256:e1f9f693559ab6db6e58a488f4ae8ceb007a4f699078c0dc22b0b7977e343ab8
Deleted: sha256:1b33688c565e1463af493558803d5e81713126f680d3793086f1f06875067589
Deleted: sha256:8cb9ebf4e7ba5b62ef5980157177c5e2d828ac6f81e0cef63c2cdafd6b9e3af3
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a7856ce2458289f29cb14ce77071d0b0bf067a1c2e6c1500c9ffaef2684944b3
  Associated tags:
 - 20230315-143230
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-143230].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a7856ce2458289f29cb14ce77071d0b0bf067a1c2e6c1500c9ffaef2684944b3].
$ rm -rf /tmp/tmp.SmucO41BXY
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315142030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315142030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315142030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e5821188101a43765b9f7f1ecd10b22d3fbb27bf4f8a1128a7935fd2edd1cfa].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315142030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315142030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315142030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e8ecd78d6f6e513f64a9c87bc1aeb830f1dfd55fa8757b7c61e70ce7310fabcd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 142021.
Stopping expansion service pid: 142022.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 40s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1404

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1404/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315082042",
            "environmentId": "cXOLKUgaqobeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201"
      }
    ]
  },
  "name": "go-testxlang_partition-841",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/15 09:17:34 Submitted job: 2023-03-15_02_17_34-9866273341956225174
2023/03/15 09:17:34 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-15_02_17_34-9866273341956225174?project=apache-beam-testing
2023/03/15 09:17:34 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-15_02_17_34-9866273341956225174
2023/03/15 09:17:34 Job state: JOB_STATE_PENDING ...
2023/03/15 09:18:04 Job still running ...
2023/03/15 09:18:34 Job still running ...
2023/03/15 09:19:04 Job still running ...
2023/03/15 09:19:34 Job still running ...
2023/03/15 09:20:05 Job still running ...
2023/03/15 09:20:35 Job still running ...
2023/03/15 09:21:05 Job still running ...
2023/03/15 09:21:35 Job still running ...
2023/03/15 09:22:05 Job still running ...
2023/03/15 09:22:35 Job still running ...
2023/03/15 09:23:05 Job still running ...
2023/03/15 09:23:35 Job still running ...
2023/03/15 09:24:05 Job still running ...
2023/03/15 09:24:35 Job still running ...
2023/03/15 09:25:05 Job still running ...
2023/03/15 09:25:35 Job still running ...
2023/03/15 09:26:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-15_02_17_34-9866273341956225174 failed
--- FAIL: TestXLang_Partition (550.99s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3240.647s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678869158344423021
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41593 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rNfNyPLuAk" is_bounded:BOUNDED windowing_strategy_id:"w0@rNfNyPLuAk"}} windowing_strategies:{key:"w0@rNfNyPLuAk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rNfNyPLuAk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rNfNyPLuAk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rNfNyPLuAk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678869158344423021\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rNfNyPLuAk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41593 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@rNfNyPLuAk" is_bounded:BOUNDED windowing_strategy_id:"w0@rNfNyPLuAk"}} windowing_strategies:{key:"w0@rNfNyPLuAk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@rNfNyPLuAk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@rNfNyPLuAk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@rNfNyPLuAk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678869158344423021\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"rNfNyPLuAk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000676400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000676400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e0f60?, 0xc00068c000?}, {0x113b38e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc0003a2d30, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e0f00?, 0xc00068c000?}, {0xc000180900, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0xe7b800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003a2d30, 0xf}, {0xc000180900, 0x52}, {0xebcb40, 0xc000128228})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000007d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000007d40, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.436s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:30bb6cca3aae9b5bcc148fe37009f5146b8e16fc33c7fc0c13f0b40e3afaefcf
Deleted: sha256:cf0bcafab72abd8338965001fe89b89dac412599d1f9beee1851495d2ca6c7ec
Deleted: sha256:5a4de74eac1db34a7647b0f1e3268697792cbe93838fa783766c232beb07bf7f
Deleted: sha256:e52fcbc00055d39426a310b8efe99491c688e8e9f0d5daa5b5d4a281df5f9301
Deleted: sha256:4fcbf481304c440a637d294d739091c5db4e0f5bc674fd0272ade573902ffe06
Deleted: sha256:d9748ccf187b4964c448809fe6fff5c5a5e382f04183be9dd464f85da8970514
Deleted: sha256:8a05498f2eff89c1d36ea1e97dfa1ae38561aa6e86b3b22e45666cb31a9e79ce
Deleted: sha256:a7f124dcada69f04475db295fd8465758c25d3232694ea75261b3bb57d009969
Deleted: sha256:6cba58ffe3b11c907cd7dffb207acc7e1be3210e346cb5051780a2349f364c65
Deleted: sha256:ad936b4f7fbead3ba3a6c993ed3a02a7c92e2179c7c5aeb6b4c8d1cc45f3b241
Deleted: sha256:cc03ff41405e37a77fdaf2d60096d8f713c773f9f05cf5a4a9e0659bd4945846
Deleted: sha256:2ef5cc0670427bc8a669226157f91a948eb7c1c3ee3e5a414fbe52a2c9a20bb3
Deleted: sha256:38557bb26dd3b2e5fe4bc657982234b9dae290213fe66c1b6d6a59826a68267f
Deleted: sha256:7b75e935505f3fdac350494d917f600e6230a7fc72fa074204a089f12b53cc41
Deleted: sha256:0208a317d0742e1a5cfdbb98106ed3d6bb8cd2f2b4dcc045c9653bc4d6d1db06
Deleted: sha256:dbf91422cf87160b799d80fea2f3d5456eaa4f1b3a17ff8efa2336a3798a6195
Deleted: sha256:8a433db40151dd32a8af509b441a5ed128ca90802e36b27b85b3ac3754a86a3e
Deleted: sha256:8475d611bfcc07fe9d682d0bcd432b43acae50dcab7158dc7332e12cf9fcecf4
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:30bb6cca3aae9b5bcc148fe37009f5146b8e16fc33c7fc0c13f0b40e3afaefcf
  Associated tags:
 - 20230315-083201
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-083201].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:30bb6cca3aae9b5bcc148fe37009f5146b8e16fc33c7fc0c13f0b40e3afaefcf].
$ rm -rf /tmp/tmp.q1ZEBFPm6B
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315082042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315082042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315082042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:84c8816f99ba5bcd90f9755e4b2bb914421602179eba7f94fe85d2eaf767ea66].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315082042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315082042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315082042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfbb2dfe408e1b95cfa30bbea227af42d6510fd2cf38af424410e70805fd45c3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2817705.
Stopping expansion service pid: 2817706.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 19s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1403

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1403/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315022042",
            "environmentId": "wFBQUyaFxhbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226"
      }
    ]
  },
  "name": "go-testxlang_partition-158",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/15 03:18:20 Submitted job: 2023-03-14_20_18_20-14870102852403779360
2023/03/15 03:18:20 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-14_20_18_20-14870102852403779360?project=apache-beam-testing
2023/03/15 03:18:20 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-14_20_18_20-14870102852403779360
2023/03/15 03:18:20 Job state: JOB_STATE_PENDING ...
2023/03/15 03:18:51 Job still running ...
2023/03/15 03:19:21 Job still running ...
2023/03/15 03:19:51 Job still running ...
2023/03/15 03:20:21 Job still running ...
2023/03/15 03:20:51 Job still running ...
2023/03/15 03:21:21 Job still running ...
2023/03/15 03:21:51 Job still running ...
2023/03/15 03:22:21 Job still running ...
2023/03/15 03:22:51 Job still running ...
2023/03/15 03:23:21 Job still running ...
2023/03/15 03:23:51 Job still running ...
2023/03/15 03:24:21 Job still running ...
2023/03/15 03:24:51 Job still running ...
2023/03/15 03:25:21 Job still running ...
2023/03/15 03:25:51 Job still running ...
2023/03/15 03:26:21 Job still running ...
2023/03/15 03:26:52 Job still running ...
2023/03/15 03:27:22 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-14_20_18_20-14870102852403779360 failed
--- FAIL: TestXLang_Partition (580.71s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3267.632s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678847607633033172
--- FAIL: TestBigQueryIO_BasicWriteRead (5.49s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38741 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@LvAALZzKCm" is_bounded:BOUNDED windowing_strategy_id:"w0@LvAALZzKCm"}} windowing_strategies:{key:"w0@LvAALZzKCm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@LvAALZzKCm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@LvAALZzKCm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@LvAALZzKCm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678847607633033172\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"LvAALZzKCm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38741 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@LvAALZzKCm" is_bounded:BOUNDED windowing_strategy_id:"w0@LvAALZzKCm"}} windowing_strategies:{key:"w0@LvAALZzKCm" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@LvAALZzKCm" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@LvAALZzKCm" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@LvAALZzKCm" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678847607633033172\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"LvAALZzKCm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 36 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000176540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000176540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000408420?, 0xc000418050?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000310ea0, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004083a0?, 0xc000418050?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7f302956a7b8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000310ea0, 0xf}, {0xc00004ca80, 0x52}, {0xebcb40, 0xc00040c0c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003f71e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003f71e0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.523s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.064s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9b26e8f0510694025b900f527e0f95912c53613760e87308fe4a7d0de403062d
Deleted: sha256:c6a9e6dcd96d9b4aae26819d840c8a1c886ae78016747d633318255c5bd95da8
Deleted: sha256:3e0b261e1251cabec03faf0a3e9700bbf5ff75330cf66c1267211cc951953cb4
Deleted: sha256:c088df6ea297593ef0636acfb221f3f8dbc48a1c59cb18f7583199e73a1f0dec
Deleted: sha256:37c81d299e1f4bd07624dc131bfa6219658521aa06ab93a1658d02fad1b8d6ac
Deleted: sha256:ba84654c931daf3bf1ffe723f8025efedb46292d546966ef9b1bd1a183952c05
Deleted: sha256:2edc88b0c90e8983dc026fd937bcf65825e0ed5a80abc06c85b9141d86f47387
Deleted: sha256:10b0f28e1b6c4923ca40d5111a0127eb83403512a0ea560c0387d925ed0dc19a
Deleted: sha256:6d5248c945af8bb6637536ae3f852684ee2917a6708b7b17b13019fc6550ddd7
Deleted: sha256:35194b1bd849d12ef339ec98ec30e99acabe8a74615ac947891046374983653c
Deleted: sha256:c525da64e8b60acbcd828c2e91a73db7b720996922af79fc6c384f7004ddf37a
Deleted: sha256:4182d5acdc947ce42c9333d01433c1afbbf6da8590d3a7990b0588b18ae848c9
Deleted: sha256:dbd052cf0b169c79bd8da1d6200f227b589f450679f6234100130b7419aba71a
Deleted: sha256:0d9ee2c8a5ad4bb512b787e54b698724e56ef292707c1951ad25bc4c66a8cb89
Deleted: sha256:727291549774c2f7d20ab3c2cb6d523b550547bbf784dccc3935184870708bdc
Deleted: sha256:2411552fc2844a7ea5cf230dc86259a12aa6b0427f170132737b1612b11ed477
Deleted: sha256:cd5aa93f1f8ff8b3a52f4f2d91b31acd1d9645af4016f1e0410b74ab3d700e87
Deleted: sha256:03f274f9c4a33660062d7f3ebed484507d7b54e6738693418cc756227adb48b4
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9b26e8f0510694025b900f527e0f95912c53613760e87308fe4a7d0de403062d
  Associated tags:
 - 20230315-023226
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230315-023226].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9b26e8f0510694025b900f527e0f95912c53613760e87308fe4a7d0de403062d].
$ rm -rf /tmp/tmp.rMrSSGPy5X
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315022042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230315022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e629e7b6197fdc1280a873c7d9e2a37680330e64aaf58f3f8c8a9ef00af2926].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315022042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315022042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230315022042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:bd15495866fd61b60daec5d1bb48229b37b72d4858852fd647a929fdf5fcad93].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2686022.
Stopping expansion service pid: 2686023.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 36s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1402

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1402/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
2023/03/14 21:39:39 Job still running ...
2023/03/14 21:40:09 Job still running ...
2023/03/14 21:40:39 Job still running ...
2023/03/14 21:41:09 Job still running ...
2023/03/14 21:41:39 Job still running ...
2023/03/14 21:42:09 Job still running ...
2023/03/14 21:42:39 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-14_14_34_08-8451951138909005539 failed
--- FAIL: TestXLang_Partition (551.80s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3398.478s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678826802356088373
--- FAIL: TestBigQueryIO_BasicWriteRead (5.47s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38693 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cgRSVHYOfc" is_bounded:BOUNDED windowing_strategy_id:"w0@cgRSVHYOfc"}} windowing_strategies:{key:"w0@cgRSVHYOfc" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cgRSVHYOfc" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cgRSVHYOfc" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cgRSVHYOfc" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678826802356088373\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cgRSVHYOfc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38693 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cgRSVHYOfc" is_bounded:BOUNDED windowing_strategy_id:"w0@cgRSVHYOfc"}} windowing_strategies:{key:"w0@cgRSVHYOfc" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cgRSVHYOfc" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cgRSVHYOfc" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cgRSVHYOfc" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678826802356088373\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cgRSVHYOfc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000294540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000294540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004090e0?, 0xc000415720?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000417000, 0xf}, 0xc000551d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000409080?, 0xc000415720?}, {0xc000526360, 0x52}, {0x1?}, {0xc000551ea8, 0x2, 0x7fc4dd5875d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000417000, 0xf}, {0xc000526360, 0x52}, {0xebcb40, 0xc00055e310})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004291e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004291e0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.507s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.042s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-204541
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-204541
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:750cc7d793838255517567caf70d7bd76515df231da88a85b4fe27789d34f910
Deleted: sha256:598557e26c1bfc0ac1822acd0af1645bb5b5124aadcced13a2c3913a12608ee8
Deleted: sha256:2b7f5526e31eca9615c0df5012566b1c389227be387ab173cc06e33ab2d7aa18
Deleted: sha256:62302bb8115c3ed4b33612740bc8cd18e46065378f43cedde3825ae056922ed9
Deleted: sha256:65e1c91ea800ff99e7f51cb01b4e4273217510ec128453fec9ec96831d0b61f6
Deleted: sha256:753384446164d30e208a224fd214fcf6549a943e423b8742cd406a4fbacc6d46
Deleted: sha256:49145a20966ca5c121d95218d1467ee392c15bc9d15ed96955c26cb73dae3a07
Deleted: sha256:6681777fbcd7c7d970ce2f6e24d2e84d24d47d8afb6d32208e9135cc8d700609
Deleted: sha256:b7bf9b71f3f7938a5073d954fe4db61092ff93bf400ef30bf8d5bcbb1fb114a9
Deleted: sha256:7ca99e802aa15e16d67b1dfb6192fee53e31f1adb78a87bd8a0b1d462416ab07
Deleted: sha256:1ce03ec5907f20bf3f678561cb31a342c4609546d63a9fe04a645c9f4a72d634
Deleted: sha256:e61af17faefdd2c38cc29827b5fd9ef7a24dd39cf672e26d65fab6d7e41f7e43
Deleted: sha256:abca95499750d51a3b5210d620d08166e74a79ee6b8bea81687b94b149025b6a
Deleted: sha256:d096406b6d8439e8622527e850e0672dbd74ecc0b203f323283c557ba250cdfe
Deleted: sha256:d1c8b84780e1ea6a83b4ba9fd11bcda3d886ecf30521e3e2e461ed67dc0d407f
Deleted: sha256:4d5b57b321bfe668698cfd7e827c496851ee235acbcfe1af84e7e84b2caab6ba
Deleted: sha256:aec384230167545f4c3bb1e0300687484a680f92b7527e4fc00f6d67cfe74998
Deleted: sha256:fd7e7f35c4a8b179c3b9d4da692327b7c62d479c1df0cbd84eb5231a0989bbcb
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-204541
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:750cc7d793838255517567caf70d7bd76515df231da88a85b4fe27789d34f910
  Associated tags:
 - 20230314-204541
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-204541
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-204541].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:750cc7d793838255517567caf70d7bd76515df231da88a85b4fe27789d34f910].
$ rm -rf /tmp/tmp.shh7zcs1Yq
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314203303
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314203303]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314203303] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:618c620cd30332d17e70105ffd4510aacbc22bf49b0173f5717771e2a1359636].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314203303
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be
Deleted: sha256:670eff30d1ba436190afcb1659f341dba853934c66f77bd301b4cb4eaec500bb
Deleted: sha256:8492129347e617c4bd95bfe0452c4fbcb7d2462800d79b93c23901128b664899
Deleted: sha256:93fbe917cf80ee79ba59b359fc11e383d9444a8d840283af8146a52d16d889ac
Deleted: sha256:225c7d0cf31d76b52e22cd4401e55480f95ab8938403e6aea1bd81007abe3a42
Deleted: sha256:0e365a7f0bbfd7013fad0d0b81c9e19ada689a6a2a947ba8de1bf610db19d500
Deleted: sha256:06d7e70dd42b1c22af6271d3c4a0809a89af15585bb2e7fb68454b5687cdb2df
Deleted: sha256:e9fea1a17d7137d2a6cc542dbe3f754b4eb185157413d08912d76dd76450daf4
Deleted: sha256:2987f00c149f730fb2959f55c61a609e1278e47bd7db9b6dc3541f99841b7494
Deleted: sha256:a5a94c1b08b716f7698740d8c8ae4c6a48157719962a4368e48e2ecf68e57849
Deleted: sha256:260169799e2a5add928f72e8ec77d94a193af17a83e8ab1c0708167c849d3a5d
Deleted: sha256:46d0dc57ba4f8e3c169310ea714e82aa747aae507df0cf862a24b351a094b2e7
Deleted: sha256:61a9702b5aa58f52a6c40c4dd5b557d42bc39b7b5a229b1e2adcac7111918cf6
Deleted: sha256:079bfed1eb82b0299db7a0dc7d2e61fbfb811a5885d8b68b256ddc171e6d46b9
Deleted: sha256:00a7d54b834a8f5ff8a5b291996261baf91b7e233e7ac15d880e7a58a5468677
Deleted: sha256:e71dd4802deb47a01f3288ddb08699a056adad3ef361f624154a0bd7353754e9
Deleted: sha256:bc0ca0d3e4b2f15f02d8a4da0be6686f826605e87ab6571f868b98182c5d7a9b
Deleted: sha256:6841d0ae1df054a574cacad12aa3c340ba8a34979e3ab055d1b06aa6c1e9174e
Deleted: sha256:0a18be7df74c038f677aac1f42bd1fc114a1dec8f28d62e92097416d69ede386
Deleted: sha256:711d0265aba8173bba78e89109edcf067f03d558309137142083bf4b3876c6c8
Deleted: sha256:44c12b0cfcb0f78ec09ea7b553277efe2c2ce0ee80bd40edd9da9a74bbf1241d
Deleted: sha256:82fd49085cd164d8cbe85eb2c22311f5a89d870ebb2adc5442bd5bc12278658c
Deleted: sha256:5fe9ad283198500673d9e6b9ca8064f82225fd9492045d20cdb220c5d1a8a703
Deleted: sha256:3153cde0f0417be61858d37e2bb5599e872565782288a4cbe3b7f1e21f6f9325
Deleted: sha256:1bf6c7687b2da5093fd11af5ef0e4cc38cc56251be03e85f2612030ee1b599a9
Deleted: sha256:00e173ec521aaa179b8c82ce8db6a0e6a1e8321029b47cdd608d19436d3ab225
Deleted: sha256:9d3e702d77173d456fa1b97edb3eb40a9aca467177fc31c7c26020e60219a67d
Deleted: sha256:65676d671195f7f0568f8ff39b57c2a59c000477aaf70db0354b1c309eb115f3
Deleted: sha256:b4896f13938cebcc8818c42ba4e4a5674856581d046890d00ad86daeacbf7b63
Deleted: sha256:204cfd0cb322fb696c1d6f4ea0b0effb7bd83563497f4806e0ea18bf7489ae6b
Deleted: sha256:0d0293c92f08120a5281180d98d33027fd9f812539bb84c9de7c58326632b863
Deleted: sha256:22f2ad83ba6de7b4547e91e62c7fe0d36847ac734fedf0f3531c123d156340e5
Deleted: sha256:82e880362299cb216d514b364888a3541c7a68f7435705d2765dca1e92528048
Deleted: sha256:2d69cc47f7a52e6605f671f4bbf2e772b3798f77164c2bbc1b9ea1f95140a48d
Deleted: sha256:dbdfac00b70014aade55db49b11a7fd1c2e6bfdaf7ce928ee938aa71ec5b31ab
Deleted: sha256:48deddc33dfcd741b33c85dbabf4f37712676af22932e89a230a185a575259d9
Deleted: sha256:85778aaba8275d0f7e8a0919e1865f2ad5c6f8d174a27545bc73752b0a30a669
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314203303]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314203303] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c7777ad36b5764536d4b68c250501ec43000b2e78d9135aeff08e069ec3c57be].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 4079995.
Stopping expansion service pid: 4079996.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 41s
232 actionable tasks: 162 executed, 58 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1401

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1401/display/redirect>

Changes:


------------------------------------------
[...truncated 1004.99 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-143153",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314142041",
            "environmentId": "zkYlTnGblAbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-143153"
      }
    ]
  },
  "name": "go-testxlang_partition-134",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/14 15:16:32 Submitted job: 2023-03-14_08_16_31-5528287080547090606
2023/03/14 15:16:32 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-14_08_16_31-5528287080547090606?project=apache-beam-testing
2023/03/14 15:16:32 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-14_08_16_31-5528287080547090606
2023/03/14 15:16:32 Job state: JOB_STATE_PENDING ...
2023/03/14 15:17:02 Job still running ...
2023/03/14 15:17:32 Job still running ...
2023/03/14 15:18:02 Job still running ...
2023/03/14 15:18:32 Job still running ...
2023/03/14 15:19:02 Job still running ...
2023/03/14 15:19:32 Job still running ...
2023/03/14 15:20:02 Job still running ...
2023/03/14 15:20:32 Job still running ...
2023/03/14 15:21:02 Job still running ...
2023/03/14 15:21:32 Job still running ...
2023/03/14 15:22:02 Job still running ...
2023/03/14 15:22:33 Job still running ...
2023/03/14 15:23:03 Job still running ...
2023/03/14 15:23:33 Job still running ...
2023/03/14 15:24:03 Job still running ...
2023/03/14 15:24:33 Job still running ...
2023/03/14 15:25:03 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-14_08_16_31-5528287080547090606 failed
--- FAIL: TestXLang_Partition (555.28s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3186.932s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678804349762216030
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33139 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KZiotXpMUK" is_bounded:BOUNDED windowing_strategy_id:"w0@KZiotXpMUK"}} windowing_strategies:{key:"w0@KZiotXpMUK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KZiotXpMUK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KZiotXpMUK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KZiotXpMUK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678804349762216030\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KZiotXpMUK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33139 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KZiotXpMUK" is_bounded:BOUNDED windowing_strategy_id:"w0@KZiotXpMUK"}} windowing_strategies:{key:"w0@KZiotXpMUK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KZiotXpMUK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KZiotXpMUK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KZiotXpMUK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678804349762216030\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KZiotXpMUK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 14 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0000ed980})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0000ed980})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6600?, 0xc00012e000?}, {0x113b38e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc0003a2e20, 0xf}, 0xc00001dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a65a0?, 0xc00012e000?}, {0xc0000de360, 0x52}, {0x1?}, {0xc00001dea8, 0x2, 0x7f9a75696f70?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003a2e20, 0xf}, {0xc0000de360, 0x52}, {0xebcb40, 0xc0001101a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000588ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000588ea0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.369s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3b4ef88a21a4f2c261f9c412f715907e8b2af4da039855bdf1f73f3f182cac6c
  Associated tags:
 - 20230314-143153
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-143153
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-143153].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3b4ef88a21a4f2c261f9c412f715907e8b2af4da039855bdf1f73f3f182cac6c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a7fbe0094827c23b90d221a9631f65bb1402ade2b3249b20f62f3320a14b89c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a7fbe0094827c23b90d221a9631f65bb1402ade2b3249b20f62f3320a14b89c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a7fbe0094827c23b90d221a9631f65bb1402ade2b3249b20f62f3320a14b89c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a7fbe0094827c23b90d221a9631f65bb1402ade2b3249b20f62f3320a14b89c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:06accbfc3fc7208b017f26b5faedaf77c1ef78cfbf568cdffc85cafb6f13b981]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:06accbfc3fc7208b017f26b5faedaf77c1ef78cfbf568cdffc85cafb6f13b981])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:06accbfc3fc7208b017f26b5faedaf77c1ef78cfbf568cdffc85cafb6f13b981
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:06accbfc3fc7208b017f26b5faedaf77c1ef78cfbf568cdffc85cafb6f13b981].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 19s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1400

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1400/display/redirect>

Changes:


------------------------------------------
[...truncated 590.75 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314082040",
            "environmentId": "uCiYBgAoZkbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252"
      }
    ]
  },
  "name": "go-testxlang_partition-328",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/14 09:18:25 Submitted job: 2023-03-14_02_18_25-5244025398340380535
2023/03/14 09:18:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-14_02_18_25-5244025398340380535?project=apache-beam-testing
2023/03/14 09:18:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-14_02_18_25-5244025398340380535
2023/03/14 09:18:25 Job state: JOB_STATE_PENDING ...
2023/03/14 09:18:55 Job still running ...
2023/03/14 09:19:25 Job still running ...
2023/03/14 09:19:55 Job still running ...
2023/03/14 09:20:25 Job still running ...
2023/03/14 09:20:55 Job still running ...
2023/03/14 09:21:25 Job still running ...
2023/03/14 09:21:56 Job still running ...
2023/03/14 09:22:26 Job still running ...
2023/03/14 09:22:56 Job still running ...
2023/03/14 09:23:26 Job still running ...
2023/03/14 09:23:56 Job still running ...
2023/03/14 09:24:26 Job still running ...
2023/03/14 09:24:56 Job still running ...
2023/03/14 09:25:26 Job still running ...
2023/03/14 09:25:56 Job still running ...
2023/03/14 09:26:26 Job still running ...
2023/03/14 09:26:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-14_02_18_25-5244025398340380535 failed
--- FAIL: TestXLang_Partition (550.97s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.291s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678782808595743620
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35187 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dWUHfIUEJA" is_bounded:BOUNDED windowing_strategy_id:"w0@dWUHfIUEJA"}} windowing_strategies:{key:"w0@dWUHfIUEJA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dWUHfIUEJA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dWUHfIUEJA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dWUHfIUEJA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678782808595743620\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dWUHfIUEJA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35187 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dWUHfIUEJA" is_bounded:BOUNDED windowing_strategy_id:"w0@dWUHfIUEJA"}} windowing_strategies:{key:"w0@dWUHfIUEJA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dWUHfIUEJA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dWUHfIUEJA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dWUHfIUEJA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678782808595743620\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dWUHfIUEJA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 37 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000598e00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000598e00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040ad20?, 0xc0000c1720?}, {0x113b38e, 0x39}, {0xc00015e0c0?, 0xa9e920?, 0x1?}, {0xc000430cb0, 0xf}, 0xc000479d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040acc0?, 0xc0000c1720?}, {0xc00004c540, 0x52}, {0x1?}, {0xc000479ea8, 0x2, 0x7f0f2c7c83c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000430cb0, 0xf}, {0xc00004c540, 0x52}, {0xebcb40, 0xc000431fc0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00041cea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00041cea0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.425s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a69fa9953517e94e8b729dafb655d6e9c24793b1987666d07003ce5dcd0976ae
Deleted: sha256:bec712685c97d7f5ce2cda63da0e1fb574f55daff707fc09ba40bc178d78dd5c
Deleted: sha256:0abed7baa0bb9c0d383314bab3710c66adb17ddd547541b8aa82d11de818e58e
Deleted: sha256:9036c0882f402aeb9861576874d36c5eaa69c82265e54f5abe02421a66974a8b
Deleted: sha256:54a46ca15504e8779219fb23abe0f85c3c154e939920a103c28908d207b9aade
Deleted: sha256:0fc922f1c74e7144d7e0078cca4ccc8a27c5e7421e57d452b9fbe3678328876e
Deleted: sha256:e9e1387b568c9ffa57c103d6e704bcab497f62ec321b11998577ae23b3f4c667
Deleted: sha256:84d543d2d4d89a16ccdd37352568d6ef11f3e0dc5c33ca0ab7ad8b5f12f6a72c
Deleted: sha256:7e57a5055331bfd7b3935c9bc4663960a0afdf7924c77ebfdc931135082404a0
Deleted: sha256:d3d73c6815edfb7f4b5b65ad4c9b56a98172621d8ff43803dc9fefbd8f9d6a84
Deleted: sha256:c4bb7759d17220cd755cc8ad7f71fb51826436de2dd8c7d6e1b6827f1bd1b8d2
Deleted: sha256:9507b112fbf1adaf672c42f0ff6c9fd86a507f1d4837c61f7320f202d8ae0b35
Deleted: sha256:ad32b491165d0bcc2043d9220c2afede9c690ad901aba49c96c538d0ba3ca337
Deleted: sha256:6ba8134d3670e006bbb0da9544bff8fe6f12ddd337799ab9871957da2e97ae47
Deleted: sha256:e91229a42f09902497021ebbd46c4e09dfdae0ebbb0c409b025e250d7b63f779
Deleted: sha256:e495c716c5f1fd4f6568310d904f27d5230baad541faa20994f74260b70eb8a6
Deleted: sha256:e678b27680ac486a977ccc3c12172151c1bfc97d762c74b80f3f5ea251689d7f
Deleted: sha256:1c35c1fb2b6ed0cab9c6264848ca533d4a253bf311d07afdcb94be47a68f1dbf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a69fa9953517e94e8b729dafb655d6e9c24793b1987666d07003ce5dcd0976ae
  Associated tags:
 - 20230314-083252
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230314-083252].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a69fa9953517e94e8b729dafb655d6e9c24793b1987666d07003ce5dcd0976ae].
$ rm -rf /tmp/tmp.wqRyYMvblV
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314082040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5e4f2c2fa75c749b6c2b35872de36fac9259032cd8b935f99e1ac357f0df270].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314082040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98b80ccd70c0bddbf5a54411e8d28a7a0f1081cacd2d7a4045cbdbb5b04fe4dd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1419517.
Stopping expansion service pid: 1419518.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 12s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1399

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1399/display/redirect>

Changes:


------------------------------------------
[...truncated 143.78 KB...]
cfb72a0c452e: Preparing
5eafae61cedb: Preparing
91e8093bf673: Preparing
2fb8db4500c6: Preparing
b2b4b51cf1a5: Preparing
b718008aad25: Preparing
e33a3f9f8966: Preparing
48e40c28adc8: Preparing
6a703692f3f6: Preparing
01995c4f6743: Preparing
cf362c96acad: Preparing
5e08b3c216b5: Preparing
918157854997: Preparing
a52ad1b21005: Preparing
dcdaccdadf66: Preparing
115ffd55709f: Preparing
0baa05faf31a: Preparing
ac504d030134: Preparing
52ebb9a789db: Preparing
86d774dafc20: Preparing
b2b4b51cf1a5: Waiting
da68f13652fc: Preparing
cf2e8433dbf2: Preparing
a52ad1b21005: Waiting
dcdaccdadf66: Waiting
b718008aad25: Waiting
115ffd55709f: Waiting
48e40c28adc8: Waiting
0baa05faf31a: Waiting
cf362c96acad: Waiting
ac504d030134: Waiting
6a703692f3f6: Waiting
5e08b3c216b5: Waiting
da68f13652fc: Waiting
86d774dafc20: Waiting
cf2e8433dbf2: Waiting
01995c4f6743: Waiting
91e8093bf673: Pushed
5eafae61cedb: Pushed
3f4a9eb2aaf8: Pushed
2fb8db4500c6: Pushed
cfb72a0c452e: Pushed
b718008aad25: Pushed
e33a3f9f8966: Pushed
48e40c28adc8: Pushed
5e08b3c216b5: Pushed
918157854997: Pushed
01995c4f6743: Pushed
dcdaccdadf66: Layer already exists
a52ad1b21005: Layer already exists
0baa05faf31a: Layer already exists
ac504d030134: Layer already exists
52ebb9a789db: Layer already exists
86d774dafc20: Layer already exists
115ffd55709f: Layer already exists
da68f13652fc: Layer already exists
cf2e8433dbf2: Layer already exists
b2b4b51cf1a5: Pushed
6a703692f3f6: Pushed
cf362c96acad: Pushed
20230314022040: digest: sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee size: 5156

> Task :runners:google-cloud-dataflow-java:setupXVR

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerSetup
Launching Java expansion service @ 44259
Launching Python expansion service @ 46061

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava
$ CURRENT_DIRECTORY=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test>
$ TESTS=./test/integration/... ./test/regression
$ RUNNER=portable
$ TIMEOUT=3h
$ SIMULTANEOUS=3
$ GCS_LOCATION=gs://temp-storage-for-end-to-end-tests
$ GCS_SUBFOLDER=test25600
$ PROJECT=apache-beam-testing
$ DATAFLOW_PROJECT=apache-beam-testing
$ REGION=us-central1
$ trap exit_background_processes SIGINT SIGTERM EXIT
$ key=--pipeline_opts
$ case --pipeline_opts in
$ PIPELINE_OPTS=--kafka_jar=<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.47.0-SNAPSHOT.jar> --expansion_jar=io:<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.47.0-SNAPSHOT.jar> --expansion_jar=schemaio:<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.47.0-SNAPSHOT.jar> --expansion_jar=debeziumio:<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.47.0-SNAPSHOT.jar> --expansion_jar=gcpio:<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.47.0-SNAPSHOT.jar> --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:44259
$ key=--runner
$ case --runner in
$ RUNNER=dataflow
$ key=--project
$ case --project in
$ PROJECT=apache-beam-testing
$ key=--dataflow_project
$ case --dataflow_project in
$ DATAFLOW_PROJECT=apache-beam-testing
$ key=--region
$ case --region in
$ REGION=us-central1
$ key=--tests
$ case --tests in
$ TESTS=./test/integration/xlang ./test/integration/io/xlang/...
$ key=--sdk_overrides
$ case --sdk_overrides in
$ SDK_OVERRIDES=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314022040
$ cd <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src>
$ test -d sdks/go/test
$ command -v docker
/usr/bin/docker
$ docker -v
Docker version 20.10.23, build 7155243
$ command -v gcloud
/usr/bin/gcloud
$ gcloud --version
Google Cloud SDK 406.0.0
alpha 2022.10.17
beta 2022.10.17
bq 2.0.79
bundled-python3-unix 3.9.12
core 2022.10.17
gcloud-crc32c 1.0.0
gsutil 5.14
$ TMPDIR=/tmp/tmp.csl4oo2Rmw
$ gcloud_ver=406.0.0
$ TAG=20230314-023210
$ CONTAINER=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
Using container us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
$ ./gradlew :sdks:go:container:docker -Pdocker-repository-root=us.gcr.io/apache-beam-testing/jenkins -Pdocker-tag=20230314-023210
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.5.1/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy UP-TO-DATE
> Task :buildSrc:pluginDescriptors UP-TO-DATE
> Task :buildSrc:processResources UP-TO-DATE
> Task :buildSrc:classes UP-TO-DATE
> Task :buildSrc:jar UP-TO-DATE
> Task :buildSrc:assemble UP-TO-DATE
> Task :buildSrc:spotlessGroovy UP-TO-DATE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.6
go1.19.6: already downloaded in /home/jenkins/sdk/go1.19.6
GOCMD=/home/jenkins/go/bin/go1.19.6
> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean
> Task :sdks:go:container:goPrepare UP-TO-DATE

> Task :sdks:go:container:goBuild
/home/jenkins/go/bin/go1.19.6 build -o ./build/target/linux_amd64/boot boot.go boot_test.go

> Task :sdks:go:container:skipPullLicenses
> Task :sdks:go:container:dockerPrepare

> Task :sdks:go:container:docker FAILED
The command '/bin/sh -c apt-get update &&     DEBIAN_FRONTEND=noninteractive apt-get install -y         ca-certificates         &&     rm -rf /var/lib/apt/lists/*' returned a non-zero code: 100

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:go:container:docker'.
> Process 'command 'docker'' finished with non-zero exit value 100

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

BUILD FAILED in 16s
16 actionable tasks: 5 executed, 11 up-to-date

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

$ ./gradlew :sdks:go:container:docker -Pdocker-repository-root=us.gcr.io/apache-beam-testing/jenkins -Pdocker-tag=20230314-023210

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314022040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230314022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6bb336f89ef1d8bc9f5eae90edf236fd550a000bf410710488d5a4b5b7daa7ee].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314022040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230314022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:799faa1c1c55edbc248f195a93cfca4a4ce9490c14e199d8cdc381a0b4a5dc23].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1233194.
Stopping expansion service pid: 1233195.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 12m 10s
232 actionable tasks: 167 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1398

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1398/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313202043",
            "environmentId": "mzlqBfXPVDbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-203328",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-203328"
      }
    ]
  },
  "name": "go-testxlang_partition-363",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/13 21:19:11 Submitted job: 2023-03-13_14_19_10-5208864879521615305
2023/03/13 21:19:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-13_14_19_10-5208864879521615305?project=apache-beam-testing
2023/03/13 21:19:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-13_14_19_10-5208864879521615305
2023/03/13 21:19:11 Job state: JOB_STATE_PENDING ...
2023/03/13 21:19:41 Job still running ...
2023/03/13 21:20:11 Job still running ...
2023/03/13 21:20:41 Job still running ...
2023/03/13 21:21:11 Job still running ...
2023/03/13 21:21:41 Job still running ...
2023/03/13 21:22:11 Job still running ...
2023/03/13 21:22:41 Job still running ...
2023/03/13 21:23:11 Job still running ...
2023/03/13 21:23:41 Job still running ...
2023/03/13 21:24:11 Job still running ...
2023/03/13 21:24:41 Job still running ...
2023/03/13 21:25:11 Job still running ...
2023/03/13 21:25:41 Job still running ...
2023/03/13 21:26:11 Job still running ...
2023/03/13 21:26:41 Job still running ...
2023/03/13 21:27:11 Job still running ...
2023/03/13 21:27:41 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-13_14_19_10-5208864879521615305 failed
--- FAIL: TestXLang_Partition (551.57s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3242.876s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678739652345009357
--- FAIL: TestBigQueryIO_BasicWriteRead (4.61s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39613 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RPiZzXTZkw" is_bounded:BOUNDED windowing_strategy_id:"w0@RPiZzXTZkw"}} windowing_strategies:{key:"w0@RPiZzXTZkw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RPiZzXTZkw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RPiZzXTZkw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RPiZzXTZkw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678739652345009357\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RPiZzXTZkw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39613 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RPiZzXTZkw" is_bounded:BOUNDED windowing_strategy_id:"w0@RPiZzXTZkw"}} windowing_strategies:{key:"w0@RPiZzXTZkw" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RPiZzXTZkw" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RPiZzXTZkw" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RPiZzXTZkw" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678739652345009357\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RPiZzXTZkw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 54 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000113400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000113400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e1740?, 0xc0000c1770?}, {0x113b38e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc0003a0d90, 0xf}, 0xc00063fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e16e0?, 0xc0000c1770?}, {0xc0001808a0, 0x52}, {0x1?}, {0xc00063fea8, 0x2, 0x7fa2701775b0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003a0d90, 0xf}, {0xc0001808a0, 0x52}, {0xebcb40, 0xc0006500a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.645s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d8cb43231a85993aec97977b6059c67b717a4537ce804ae051d491006553dda9
  Associated tags:
 - 20230313-203328
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-203328
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-203328].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d8cb43231a85993aec97977b6059c67b717a4537ce804ae051d491006553dda9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313202043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:487b4e007d21e1804ff6640217722475f8bd4d21675f1a4163275605d941ccbd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313202043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:487b4e007d21e1804ff6640217722475f8bd4d21675f1a4163275605d941ccbd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:487b4e007d21e1804ff6640217722475f8bd4d21675f1a4163275605d941ccbd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:487b4e007d21e1804ff6640217722475f8bd4d21675f1a4163275605d941ccbd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313202043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d58c17456837c6f869452bbcf2155f06905350383865decb70bcfab0c552a653]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313202043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d58c17456837c6f869452bbcf2155f06905350383865decb70bcfab0c552a653])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d58c17456837c6f869452bbcf2155f06905350383865decb70bcfab0c552a653
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d58c17456837c6f869452bbcf2155f06905350383865decb70bcfab0c552a653].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 57s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1397

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1397/display/redirect?page=changes>

Changes:

[noreply] Mark that 2.46 has been released now that the release is finalized


------------------------------------------
[...truncated 1022.60 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-143257",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313142041",
            "environmentId": "mbmkqiDtCTbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-143257"
      }
    ]
  },
  "name": "go-testxlang_partition-957",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/13 15:17:34 Submitted job: 2023-03-13_08_17_33-15316968176546404586
2023/03/13 15:17:34 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-13_08_17_33-15316968176546404586?project=apache-beam-testing
2023/03/13 15:17:34 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-13_08_17_33-15316968176546404586
2023/03/13 15:17:34 Job state: JOB_STATE_PENDING ...
2023/03/13 15:18:04 Job still running ...
2023/03/13 15:18:34 Job still running ...
2023/03/13 15:19:04 Job still running ...
2023/03/13 15:19:34 Job still running ...
2023/03/13 15:20:04 Job still running ...
2023/03/13 15:20:34 Job still running ...
2023/03/13 15:21:04 Job still running ...
2023/03/13 15:21:34 Job still running ...
2023/03/13 15:22:04 Job still running ...
2023/03/13 15:22:34 Job still running ...
2023/03/13 15:23:04 Job still running ...
2023/03/13 15:23:34 Job still running ...
2023/03/13 15:24:05 Job still running ...
2023/03/13 15:24:35 Job still running ...
2023/03/13 15:25:05 Job still running ...
2023/03/13 15:25:35 Job still running ...
2023/03/13 15:26:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-13_08_17_33-15316968176546404586 failed
--- FAIL: TestXLang_Partition (553.77s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3181.678s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678718017091648976
--- FAIL: TestBigQueryIO_BasicWriteRead (4.81s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36655 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aYUYhTSovP" is_bounded:BOUNDED windowing_strategy_id:"w0@aYUYhTSovP"}} windowing_strategies:{key:"w0@aYUYhTSovP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aYUYhTSovP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aYUYhTSovP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aYUYhTSovP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678718017091648976\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aYUYhTSovP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36655 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aYUYhTSovP" is_bounded:BOUNDED windowing_strategy_id:"w0@aYUYhTSovP"}} windowing_strategies:{key:"w0@aYUYhTSovP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aYUYhTSovP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aYUYhTSovP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aYUYhTSovP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678718017091648976\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aYUYhTSovP"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 36 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000556ac0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000556ac0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a76e0?, 0xc0000bda40?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000312da0, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7680?, 0xc0000bda40?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7fbce34c1448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000312da0, 0xf}, {0xc00004ca80, 0x52}, {0xebcb40, 0xc0000423b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003faea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003faea0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.851s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.042s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:df92bbfdfee190b44abd1daf2e2c1efb367f72b636040680838c9a93377326c8
  Associated tags:
 - 20230313-143257
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-143257
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-143257].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:df92bbfdfee190b44abd1daf2e2c1efb367f72b636040680838c9a93377326c8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:674fec8ebc03dbd8b68d46c7f13ea9e1c894f2f51f0546f1b21116879c6806fd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:674fec8ebc03dbd8b68d46c7f13ea9e1c894f2f51f0546f1b21116879c6806fd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:674fec8ebc03dbd8b68d46c7f13ea9e1c894f2f51f0546f1b21116879c6806fd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:674fec8ebc03dbd8b68d46c7f13ea9e1c894f2f51f0546f1b21116879c6806fd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2a9b2ccb51764d919d15d1c6e419c64aca1722227ed3c0324627cb64eb4f39]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2a9b2ccb51764d919d15d1c6e419c64aca1722227ed3c0324627cb64eb4f39])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2a9b2ccb51764d919d15d1c6e419c64aca1722227ed3c0324627cb64eb4f39
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ae2a9b2ccb51764d919d15d1c6e419c64aca1722227ed3c0324627cb64eb4f39].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 20s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1396

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1396/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-083155",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313082029",
            "environmentId": "hLOcUiDbClbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-083155"
      }
    ]
  },
  "name": "go-testxlang_partition-146",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/13 09:17:57 Submitted job: 2023-03-13_02_17_57-9061592132187009411
2023/03/13 09:17:57 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-13_02_17_57-9061592132187009411?project=apache-beam-testing
2023/03/13 09:17:57 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-13_02_17_57-9061592132187009411
2023/03/13 09:17:57 Job state: JOB_STATE_PENDING ...
2023/03/13 09:18:28 Job still running ...
2023/03/13 09:18:58 Job still running ...
2023/03/13 09:19:28 Job still running ...
2023/03/13 09:19:58 Job still running ...
2023/03/13 09:20:28 Job still running ...
2023/03/13 09:20:58 Job still running ...
2023/03/13 09:21:28 Job still running ...
2023/03/13 09:21:58 Job still running ...
2023/03/13 09:22:28 Job still running ...
2023/03/13 09:22:58 Job still running ...
2023/03/13 09:23:28 Job still running ...
2023/03/13 09:23:58 Job still running ...
2023/03/13 09:24:28 Job still running ...
2023/03/13 09:24:58 Job still running ...
2023/03/13 09:25:28 Job still running ...
2023/03/13 09:25:59 Job still running ...
2023/03/13 09:26:29 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-13_02_17_57-9061592132187009411 failed
--- FAIL: TestXLang_Partition (550.72s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3270.212s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678696352026128284
--- FAIL: TestBigQueryIO_BasicWriteRead (4.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44355 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@uxKtdXWTDM" is_bounded:BOUNDED windowing_strategy_id:"w0@uxKtdXWTDM"}} windowing_strategies:{key:"w0@uxKtdXWTDM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@uxKtdXWTDM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@uxKtdXWTDM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@uxKtdXWTDM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678696352026128284\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"uxKtdXWTDM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44355 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@uxKtdXWTDM" is_bounded:BOUNDED windowing_strategy_id:"w0@uxKtdXWTDM"}} windowing_strategies:{key:"w0@uxKtdXWTDM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@uxKtdXWTDM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@uxKtdXWTDM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@uxKtdXWTDM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678696352026128284\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"uxKtdXWTDM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000644540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000644540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040cdc0?, 0xc000419720?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000312d10, 0xf}, 0xc000199d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040cd60?, 0xc000419720?}, {0xc0000e6300, 0x52}, {0x1?}, {0xc000199ea8, 0x2, 0x7f83284c40f8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000312d10, 0xf}, {0xc0000e6300, 0x52}, {0xebcb40, 0xc0001ce020})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00042b520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00042b520, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.498s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:208f82dddb5b6d9379d86ce69f5640397800e9fe7a3293f448c46674a0c99378
  Associated tags:
 - 20230313-083155
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-083155
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-083155].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:208f82dddb5b6d9379d86ce69f5640397800e9fe7a3293f448c46674a0c99378].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20ac88787dfb5ca681d09bcf9c17a146d4d91aff7d021418b811ac87313d625f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20ac88787dfb5ca681d09bcf9c17a146d4d91aff7d021418b811ac87313d625f])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20ac88787dfb5ca681d09bcf9c17a146d4d91aff7d021418b811ac87313d625f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20ac88787dfb5ca681d09bcf9c17a146d4d91aff7d021418b811ac87313d625f].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6ab223a99d36dc7143b9c872b2bd6ac408f374cdd785df979a5158559d346ed]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6ab223a99d36dc7143b9c872b2bd6ac408f374cdd785df979a5158559d346ed])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6ab223a99d36dc7143b9c872b2bd6ac408f374cdd785df979a5158559d346ed
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e6ab223a99d36dc7143b9c872b2bd6ac408f374cdd785df979a5158559d346ed].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 56s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2b4xf2nzx34mq

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1395

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1395/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313022041",
            "environmentId": "NIyDmkRSVwbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148"
      }
    ]
  },
  "name": "go-testxlang_partition-392",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/13 03:17:19 Submitted job: 2023-03-12_20_17_18-2031984509081816638
2023/03/13 03:17:19 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-12_20_17_18-2031984509081816638?project=apache-beam-testing
2023/03/13 03:17:19 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-12_20_17_18-2031984509081816638
2023/03/13 03:17:19 Job state: JOB_STATE_PENDING ...
2023/03/13 03:17:49 Job still running ...
2023/03/13 03:18:19 Job still running ...
2023/03/13 03:18:49 Job still running ...
2023/03/13 03:19:19 Job still running ...
2023/03/13 03:19:49 Job still running ...
2023/03/13 03:20:19 Job still running ...
2023/03/13 03:20:49 Job still running ...
2023/03/13 03:21:19 Job still running ...
2023/03/13 03:21:49 Job still running ...
2023/03/13 03:22:19 Job still running ...
2023/03/13 03:22:49 Job still running ...
2023/03/13 03:23:19 Job still running ...
2023/03/13 03:23:49 Job still running ...
2023/03/13 03:24:20 Job still running ...
2023/03/13 03:24:50 Job still running ...
2023/03/13 03:25:20 Job still running ...
2023/03/13 03:25:50 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-12_20_17_18-2031984509081816638 failed
--- FAIL: TestXLang_Partition (550.67s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3236.750s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678674746864928704
--- FAIL: TestBigQueryIO_BasicWriteRead (4.28s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@fdNQtVgMny" is_bounded:BOUNDED windowing_strategy_id:"w0@fdNQtVgMny"}} windowing_strategies:{key:"w0@fdNQtVgMny" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@fdNQtVgMny" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@fdNQtVgMny" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@fdNQtVgMny" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678674746864928704\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"fdNQtVgMny"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@fdNQtVgMny" is_bounded:BOUNDED windowing_strategy_id:"w0@fdNQtVgMny"}} windowing_strategies:{key:"w0@fdNQtVgMny" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@fdNQtVgMny" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@fdNQtVgMny" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@fdNQtVgMny" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678674746864928704\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"fdNQtVgMny"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000281e40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000281e40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001171c0?, 0xc000135720?}, {0x113b38e, 0x39}, {0xc0000ee0c0?, 0xa9e920?, 0x1?}, {0xc000312e60, 0xf}, 0xc000271d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000117160?, 0xc000135720?}, {0xc0000e6300, 0x52}, {0x1?}, {0xc000271ea8, 0x2, 0x7f6722d74448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000312e60, 0xf}, {0xc0000e6300, 0x52}, {0xebcb40, 0xc000042560})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000414ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000414ea0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.312s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:49aa60df6ff4962a87ae1eef5751534d349c23b369ec19dd0ab55e53609d08fd
Deleted: sha256:7e4b10f560da175c8cb79ce6d2ac55595bc9e337d35bd179f9d65fe824269dd6
Deleted: sha256:949859364ccae98a4b2c8afb6b19fbb384a94e752ddd1d0f0755302c6a1385b7
Deleted: sha256:acc0ad8f2b7d253bc1b406814850349e493b685db4172f49ea56e962f2c89c85
Deleted: sha256:78c6fb2fc5f1eee60fad9374959bca906b82b536ccab68524e795b2f7dbbaf3d
Deleted: sha256:a75d68f85cf2a25044b2e58cc147d492a113877d66a35922d681c3fe955ade36
Deleted: sha256:11c84e20102dbb9bc9483e69702eb772186c6ce8397b13aac5823af814704427
Deleted: sha256:1ddb244159651cf18c91fa270a3b67ae3f7680c23211e5d67b77e24f4e5fab6b
Deleted: sha256:f33815cc2b0a78eb17c0bbab42ae4ee09f5362802eac22cf42b08d8005884ea6
Deleted: sha256:9137561c4af9c4dd0011f29c3461c3d200acc5b302f16393c0242247c2d1910e
Deleted: sha256:7783a744f0097a3e940e45c10168cf8026c26eca39ef4a31062f0b9ba3ebfda6
Deleted: sha256:5caf5c01ed2af909b5a31a8d9512c32b7fff41f891cbdcdeec94ce0cd8594af3
Deleted: sha256:80222d15119273c3e508af44dc1ddd497d958dcc9417a8e8e1413d4517c95030
Deleted: sha256:9b48aef7fde493742464deecc77c2261824394e83a01f52a91f4b6eec2ba8dfe
Deleted: sha256:72cc05103b00208b7fa05aab9c9e73ea0bdda7f881a8e1bd20b17a62c7f6df61
Deleted: sha256:d1e1d9f8c387869334294a980da4dca377b5762f0a89cd7b17e4cb97399bcc20
Deleted: sha256:b225ebb8e81d7453cd11636a53ef1da29247f356bb4d4c262a1fc087d6429d02
Deleted: sha256:ecfa507929cecb0ea9ae96d350c5466e1b43774d87bc72505c1183177f7c736a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:49aa60df6ff4962a87ae1eef5751534d349c23b369ec19dd0ab55e53609d08fd
  Associated tags:
 - 20230313-023148
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230313-023148].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:49aa60df6ff4962a87ae1eef5751534d349c23b369ec19dd0ab55e53609d08fd].
$ rm -rf /tmp/tmp.YUmssbs8jq
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230313022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:28017ea09ba196cee320a34fc0b432ce082d9671638eb5711317987912eccccf].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230313022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dbe25d4dd233368eeb61c354b9e41251befa8664996279d250d05ef789783513].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3876650.
Stopping expansion service pid: 3876651.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 4s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1394

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1394/display/redirect>

Changes:


------------------------------------------
[...truncated 591.78 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312202031",
            "environmentId": "sZSyryzpmLbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237"
      }
    ]
  },
  "name": "go-testxlang_partition-78",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/12 21:16:37 Submitted job: 2023-03-12_14_16_37-1823202990695503176
2023/03/12 21:16:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-12_14_16_37-1823202990695503176?project=apache-beam-testing
2023/03/12 21:16:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-12_14_16_37-1823202990695503176
2023/03/12 21:16:38 Job state: JOB_STATE_PENDING ...
2023/03/12 21:17:08 Job still running ...
2023/03/12 21:17:38 Job still running ...
2023/03/12 21:18:08 Job still running ...
2023/03/12 21:18:38 Job still running ...
2023/03/12 21:19:08 Job still running ...
2023/03/12 21:19:38 Job still running ...
2023/03/12 21:20:08 Job still running ...
2023/03/12 21:20:38 Job still running ...
2023/03/12 21:21:08 Job still running ...
2023/03/12 21:21:38 Job still running ...
2023/03/12 21:22:08 Job still running ...
2023/03/12 21:22:38 Job still running ...
2023/03/12 21:23:08 Job still running ...
2023/03/12 21:23:38 Job still running ...
2023/03/12 21:24:08 Job still running ...
2023/03/12 21:24:38 Job still running ...
2023/03/12 21:25:08 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-12_14_16_37-1823202990695503176 failed
--- FAIL: TestXLang_Partition (550.51s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3148.572s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678653193767558432
--- FAIL: TestBigQueryIO_BasicWriteRead (4.36s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33869 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@WSyqzVoFhg" is_bounded:BOUNDED windowing_strategy_id:"w0@WSyqzVoFhg"}} windowing_strategies:{key:"w0@WSyqzVoFhg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@WSyqzVoFhg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@WSyqzVoFhg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@WSyqzVoFhg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678653193767558432\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"WSyqzVoFhg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33869 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@WSyqzVoFhg" is_bounded:BOUNDED windowing_strategy_id:"w0@WSyqzVoFhg"}} windowing_strategies:{key:"w0@WSyqzVoFhg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@WSyqzVoFhg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@WSyqzVoFhg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@WSyqzVoFhg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678653193767558432\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"WSyqzVoFhg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000583800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000583800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e960?, 0xc0005bf630?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc000122aa0, 0xf}, 0xc000551d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e900?, 0xc0005bf630?}, {0xc000130300, 0x52}, {0x1?}, {0xc000551ea8, 0x2, 0x7f72441f5c40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122aa0, 0xf}, {0xc000130300, 0x52}, {0xebcb40, 0xc000123db0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102d00, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.394s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:17b7c6f8f63cafb0fd5953d31a89f544eba2045a51e4b3d5417cdbfbb9fd9b3f
Deleted: sha256:07f70b37958f3f454aec4f17877bf845c12c6ff15ddf87a7bae1f62849ce0f68
Deleted: sha256:ae1eeeea784bf41a7f12bb4e65f948a8c07b00f85cd2dd13f20ed4fde8d96817
Deleted: sha256:75bd186ccf5eed0a2ad5903c47d7d10625f2aead3c9169188640e4b31a0bf0fc
Deleted: sha256:5ab8a7d0e104a8a4ba30663db162e7fd8106f99e6393f0bd06f1288e1ea1dc68
Deleted: sha256:5a909166533d2ca22cfbb59ee4b3d186a800df84a586ee9b99cff4372fab2936
Deleted: sha256:aa680cbc3fc2bec7e9ec2ced8f77f987608c8c240ac0043719057406751f4d85
Deleted: sha256:746a1032e38a9ecd0574c2d2e6f2b1b53e02e3ecd7164c6ce3f13704dba77382
Deleted: sha256:3245b29457fe8038f59ca9671e4deadc1fa24560ec887b02c340d424793ac1f4
Deleted: sha256:d4d58b440d106905a94c68e6e72cb41237eee69493e03a224a3f100a474bacb7
Deleted: sha256:8178e5e289b5a89836d7ff5112e6fc8b3741b039eab7af42ef8a8744a1d03e48
Deleted: sha256:306eb974c01fd912379933cb0188ace9f524412246aeee015a7d9bbbdc6b75fa
Deleted: sha256:7620707f2f928cb3563874ad8520cc4a12c893ea5ca70197cfbd0b1a32a0e367
Deleted: sha256:39ee06b2025cc3dfba7fec557afe468345817ae615d530d555f7a06732d4b1e5
Deleted: sha256:ddccff96443dcb7aab64bdc2a8ba50bcd4f1eb9faf7441b1961ebf005a2d387e
Deleted: sha256:736c119610fb29b2747d5cf39f447e8081a131d353d1e133c85c4f975ef2505f
Deleted: sha256:03dddc3fb73dbf8d87100d4ad7e6a0fa7ba8f4072cb0990c0a4556d707be56f1
Deleted: sha256:f37f59acdfb2e4f2894a0d0f90d9d68d526872999c6027b81e6069d28e81a170
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:17b7c6f8f63cafb0fd5953d31a89f544eba2045a51e4b3d5417cdbfbb9fd9b3f
  Associated tags:
 - 20230312-203237
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-203237].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:17b7c6f8f63cafb0fd5953d31a89f544eba2045a51e4b3d5417cdbfbb9fd9b3f].
$ rm -rf /tmp/tmp.bYUL3I0uNY
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312202031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:150533d72472631029db6987689d84bd29e57f5a0290718ab126f4489e4395d5].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312202031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312202031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312202031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e0832c86e0b556b4cf9fc6801d08f4f63f4aa6ccb50d3b9d64d8db99ec033208].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3770875.
Stopping expansion service pid: 3770876.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 33s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1393

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1393/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-143219",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312142043",
            "environmentId": "zYVUOzpkWybeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-143219"
      }
    ]
  },
  "name": "go-testxlang_partition-642",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/12 15:16:54 Submitted job: 2023-03-12_08_16_53-12534420077765669359
2023/03/12 15:16:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-12_08_16_53-12534420077765669359?project=apache-beam-testing
2023/03/12 15:16:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-12_08_16_53-12534420077765669359
2023/03/12 15:16:54 Job state: JOB_STATE_PENDING ...
2023/03/12 15:17:24 Job still running ...
2023/03/12 15:17:54 Job still running ...
2023/03/12 15:18:24 Job still running ...
2023/03/12 15:18:54 Job still running ...
2023/03/12 15:19:24 Job still running ...
2023/03/12 15:19:54 Job still running ...
2023/03/12 15:20:24 Job still running ...
2023/03/12 15:20:54 Job still running ...
2023/03/12 15:21:24 Job still running ...
2023/03/12 15:21:54 Job still running ...
2023/03/12 15:22:24 Job still running ...
2023/03/12 15:22:54 Job still running ...
2023/03/12 15:23:25 Job still running ...
2023/03/12 15:23:55 Job still running ...
2023/03/12 15:24:25 Job still running ...
2023/03/12 15:24:55 Job still running ...
2023/03/12 15:25:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-12_08_16_53-12534420077765669359 failed
--- FAIL: TestXLang_Partition (551.20s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3182.939s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678631575695823742
--- FAIL: TestBigQueryIO_BasicWriteRead (4.47s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34979 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@yBJPCWcKAl" is_bounded:BOUNDED windowing_strategy_id:"w0@yBJPCWcKAl"}} windowing_strategies:{key:"w0@yBJPCWcKAl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@yBJPCWcKAl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@yBJPCWcKAl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@yBJPCWcKAl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678631575695823742\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"yBJPCWcKAl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34979 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@yBJPCWcKAl" is_bounded:BOUNDED windowing_strategy_id:"w0@yBJPCWcKAl"}} windowing_strategies:{key:"w0@yBJPCWcKAl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@yBJPCWcKAl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@yBJPCWcKAl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@yBJPCWcKAl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678631575695823742\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"yBJPCWcKAl"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0005ddbc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0005ddbc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169700?, 0xc00049b720?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000658c40, 0xf}, 0xc0005bdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001696a0?, 0xc00049b720?}, {0xc000590300, 0x52}, {0x1?}, {0xc0005bdea8, 0x2, 0x7fcaecefaa10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000658c40, 0xf}, {0xc000590300, 0x52}, {0xebcb40, 0xc000659f50})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ad380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ad380, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.502s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:57efbd5f594f70ea3d7b58617fce901a60f61286cb32f7e3c9169106a7ba9a8c
  Associated tags:
 - 20230312-143219
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-143219
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-143219].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:57efbd5f594f70ea3d7b58617fce901a60f61286cb32f7e3c9169106a7ba9a8c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b818dc43df2a971b453cc88b1b2b97dc2b41b47d3df33f77a6949b5d53ecfe58]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b818dc43df2a971b453cc88b1b2b97dc2b41b47d3df33f77a6949b5d53ecfe58])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b818dc43df2a971b453cc88b1b2b97dc2b41b47d3df33f77a6949b5d53ecfe58
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b818dc43df2a971b453cc88b1b2b97dc2b41b47d3df33f77a6949b5d53ecfe58].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:23ec800adc190b6693cec9bfc5e080ad61d8bbd4e444d583b03754fd47b17c59]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:23ec800adc190b6693cec9bfc5e080ad61d8bbd4e444d583b03754fd47b17c59])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:23ec800adc190b6693cec9bfc5e080ad61d8bbd4e444d583b03754fd47b17c59
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:23ec800adc190b6693cec9bfc5e080ad61d8bbd4e444d583b03754fd47b17c59].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 39s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1392

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1392/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312082029",
            "environmentId": "saJzqkusncbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-083134",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-083134"
      }
    ]
  },
  "name": "go-testxlang_partition-445",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/12 09:16:35 Submitted job: 2023-03-12_01_16_35-4417325081457183522
2023/03/12 09:16:35 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-12_01_16_35-4417325081457183522?project=apache-beam-testing
2023/03/12 09:16:35 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-12_01_16_35-4417325081457183522
2023/03/12 09:16:35 Job state: JOB_STATE_PENDING ...
2023/03/12 09:17:05 Job still running ...
2023/03/12 09:17:35 Job still running ...
2023/03/12 09:18:05 Job still running ...
2023/03/12 09:18:35 Job still running ...
2023/03/12 09:19:06 Job still running ...
2023/03/12 09:19:36 Job still running ...
2023/03/12 09:20:06 Job still running ...
2023/03/12 09:20:36 Job still running ...
2023/03/12 09:21:06 Job still running ...
2023/03/12 09:21:36 Job still running ...
2023/03/12 09:22:06 Job still running ...
2023/03/12 09:22:36 Job still running ...
2023/03/12 09:23:06 Job still running ...
2023/03/12 09:23:36 Job still running ...
2023/03/12 09:24:06 Job still running ...
2023/03/12 09:24:36 Job still running ...
2023/03/12 09:25:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-12_01_16_35-4417325081457183522 failed
--- FAIL: TestXLang_Partition (551.40s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.156s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678609929960983550
--- FAIL: TestBigQueryIO_BasicWriteRead (4.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46051 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@EROuiTTOmz" is_bounded:BOUNDED windowing_strategy_id:"w0@EROuiTTOmz"}} windowing_strategies:{key:"w0@EROuiTTOmz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@EROuiTTOmz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@EROuiTTOmz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@EROuiTTOmz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678609929960983550\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"EROuiTTOmz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46051 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@EROuiTTOmz" is_bounded:BOUNDED windowing_strategy_id:"w0@EROuiTTOmz"}} windowing_strategies:{key:"w0@EROuiTTOmz" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@EROuiTTOmz" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@EROuiTTOmz" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@EROuiTTOmz" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678609929960983550\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"EROuiTTOmz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0000e4140})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0000e4140})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fc0?, 0xc0000b8280?}, {0x113b38e, 0x39}, {0xc0000ee0c0?, 0xa9e920?, 0x1?}, {0xc00041f050, 0xf}, 0xc000225d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f60?, 0xc0000b8280?}, {0xc0005c2480, 0x52}, {0x1?}, {0xc000225ea8, 0x2, 0x7fd119607e88?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00041f050, 0xf}, {0xc0005c2480, 0x52}, {0xebcb40, 0xc000312110})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00040ba00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00040ba00, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.417s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19ed4abb918c628fb1a814dbb0130b55519618b0147087a2530177ba7ad9f0d8
  Associated tags:
 - 20230312-083134
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-083134
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-083134].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19ed4abb918c628fb1a814dbb0130b55519618b0147087a2530177ba7ad9f0d8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b764979441cd9fc625a6db3e2b1218e703bc0e16dadb14a9032e8277b27b446]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b764979441cd9fc625a6db3e2b1218e703bc0e16dadb14a9032e8277b27b446])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b764979441cd9fc625a6db3e2b1218e703bc0e16dadb14a9032e8277b27b446
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b764979441cd9fc625a6db3e2b1218e703bc0e16dadb14a9032e8277b27b446].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312082029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a6c2b0dd51278f9de4d02fcd799ee780270259755d7557e66c60b65b4851c5ce]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312082029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a6c2b0dd51278f9de4d02fcd799ee780270259755d7557e66c60b65b4851c5ce])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a6c2b0dd51278f9de4d02fcd799ee780270259755d7557e66c60b65b4851c5ce
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a6c2b0dd51278f9de4d02fcd799ee780270259755d7557e66c60b65b4851c5ce].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 32s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1391

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1391/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312022041",
            "environmentId": "vIJNZDyTfbbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204"
      }
    ]
  },
  "name": "go-testxlang_partition-550",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/12 03:16:05 Submitted job: 2023-03-11_19_16_05-1570426466644952503
2023/03/12 03:16:05 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-11_19_16_05-1570426466644952503?project=apache-beam-testing
2023/03/12 03:16:05 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-11_19_16_05-1570426466644952503
2023/03/12 03:16:05 Job state: JOB_STATE_PENDING ...
2023/03/12 03:16:35 Job still running ...
2023/03/12 03:17:05 Job still running ...
2023/03/12 03:17:35 Job still running ...
2023/03/12 03:18:05 Job still running ...
2023/03/12 03:18:35 Job still running ...
2023/03/12 03:19:05 Job still running ...
2023/03/12 03:19:35 Job still running ...
2023/03/12 03:20:05 Job still running ...
2023/03/12 03:20:36 Job still running ...
2023/03/12 03:21:06 Job still running ...
2023/03/12 03:21:36 Job still running ...
2023/03/12 03:22:06 Job still running ...
2023/03/12 03:22:36 Job still running ...
2023/03/12 03:23:06 Job still running ...
2023/03/12 03:23:36 Job still running ...
2023/03/12 03:24:06 Job still running ...
2023/03/12 03:24:36 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-11_19_16_05-1570426466644952503 failed
--- FAIL: TestXLang_Partition (550.79s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3148.378s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678588361626413578
--- FAIL: TestBigQueryIO_BasicWriteRead (4.52s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43069 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BxVuBdplzQ" is_bounded:BOUNDED windowing_strategy_id:"w0@BxVuBdplzQ"}} windowing_strategies:{key:"w0@BxVuBdplzQ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BxVuBdplzQ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BxVuBdplzQ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BxVuBdplzQ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678588361626413578\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BxVuBdplzQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43069 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BxVuBdplzQ" is_bounded:BOUNDED windowing_strategy_id:"w0@BxVuBdplzQ"}} windowing_strategies:{key:"w0@BxVuBdplzQ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BxVuBdplzQ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BxVuBdplzQ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BxVuBdplzQ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678588361626413578\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BxVuBdplzQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 14 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0005826c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0005826c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000110740?, 0xc00010ecd0?}, {0x113b38e, 0x39}, {0xc0000f00c0?, 0xa9e920?, 0x1?}, {0xc0001246b0, 0xf}, 0xc000555d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001106e0?, 0xc00010ecd0?}, {0xc00013c360, 0x52}, {0x1?}, {0xc000555ea8, 0x2, 0x7fb9dc64dbb8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001246b0, 0xf}, {0xc00013c360, 0x52}, {0xebcb40, 0xc0001259c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.553s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e544301f68b14d6244a3586235327849f8e2ae8c322d6da7aab203a42f3a792d
Deleted: sha256:99f5451083643e48f693a0303cd57e7278774e377a57a41f9478219b597e2fab
Deleted: sha256:d852a9db12320a8585afd824d239c96f98ff263c8d183f4ef8c51b1e3a15709e
Deleted: sha256:7f44b91c65181dc95727671ed32a1d5164f48aa973e91fc6437815ec754ef41a
Deleted: sha256:149f9725077f2545bfd132f01c6c94d4f1ea2b99cfb6dcf3e946bb8c381a602b
Deleted: sha256:137451925ec73983af26b33beededf9edd83df15db2b022204658097238cccab
Deleted: sha256:c0d3c2668254d6bfe635a523b6c0b446ac08f93085882a34269ce1fe125c5b6f
Deleted: sha256:ecc3a1bc77244cb90b2c1bb177579599d4b232cc832a889d8f764f592e428dab
Deleted: sha256:5ba9f5fade85e1b8a411cad638d4d83c8c69239b392a20b165a68916100b9a23
Deleted: sha256:2f2a489d89c07fe05cfd8c2330d2707413491cd3ac57bf02ca485409578880f9
Deleted: sha256:50783fe91112cdd6cd9ade9190a3adb2794825315e1fad202e9c11e3b0e3d8c3
Deleted: sha256:3888eaab8502cc11c633cd5b56ac0d55b94de1485bb6f85eb818b8ca75413743
Deleted: sha256:07d9513996c27e9b1032310ffc9856d31ff342b193c2453858ca01f1911474e0
Deleted: sha256:1ae9f148472fa110570bde8d20089ae4b4c9f8a272dbc442592eb2b126ed010d
Deleted: sha256:bb07ff8940f82acb802e6e9d776f6a19ca34970fe964981ebfbfc533772ea0f8
Deleted: sha256:76a5db99a0c75bc6bafdd67ab40f74874dd0db05acb0e784b516797cbe1f1a3d
Deleted: sha256:ad299c8ccbea1296aa19058ac1b2b1949a859214db5a1a57b3632bd0b49b628a
Deleted: sha256:d8ccc0bff7a763734d00555d503f91d4514dba3ad0902d546ae35090961502bf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e544301f68b14d6244a3586235327849f8e2ae8c322d6da7aab203a42f3a792d
  Associated tags:
 - 20230312-023204
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230312-023204].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e544301f68b14d6244a3586235327849f8e2ae8c322d6da7aab203a42f3a792d].
$ rm -rf /tmp/tmp.9bjf8NVylK
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230312022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a2e51f85107d54cf0f68f1cb3773b5bff037e2e01bb82d14419fdfa286ee57d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312022041
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312022041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230312022041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcde1d04b8c375b238645a2d8d9ad1f053a4cfc31903de1b1b7ab555dae4ca44].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3333453.
Stopping expansion service pid: 3333454.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 51s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1390

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1390/display/redirect>

Changes:


------------------------------------------
[...truncated 559.45 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311202042",
            "environmentId": "qkWIFInAABbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230"
      }
    ]
  },
  "name": "go-testxlang_partition-889",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/11 21:17:28 Submitted job: 2023-03-11_13_17_27-7537588657630987405
2023/03/11 21:17:28 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-11_13_17_27-7537588657630987405?project=apache-beam-testing
2023/03/11 21:17:28 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-11_13_17_27-7537588657630987405
2023/03/11 21:17:28 Job state: JOB_STATE_PENDING ...
2023/03/11 21:17:58 Job still running ...
2023/03/11 21:18:28 Job still running ...
2023/03/11 21:18:58 Job still running ...
2023/03/11 21:19:28 Job still running ...
2023/03/11 21:19:58 Job still running ...
2023/03/11 21:20:28 Job still running ...
2023/03/11 21:20:58 Job still running ...
2023/03/11 21:21:28 Job still running ...
2023/03/11 21:21:58 Job still running ...
2023/03/11 21:22:28 Job still running ...
2023/03/11 21:22:58 Job still running ...
2023/03/11 21:23:29 Job still running ...
2023/03/11 21:23:59 Job still running ...
2023/03/11 21:24:29 Job still running ...
2023/03/11 21:24:59 Job still running ...
2023/03/11 21:25:29 Job still running ...
2023/03/11 21:25:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-11_13_17_27-7537588657630987405 failed
--- FAIL: TestXLang_Partition (550.22s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3204.844s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678566787623480938
--- FAIL: TestBigQueryIO_BasicWriteRead (4.42s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41817 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oDVZXSFIwa" is_bounded:BOUNDED windowing_strategy_id:"w0@oDVZXSFIwa"}} windowing_strategies:{key:"w0@oDVZXSFIwa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oDVZXSFIwa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oDVZXSFIwa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oDVZXSFIwa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678566787623480938\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oDVZXSFIwa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41817 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oDVZXSFIwa" is_bounded:BOUNDED windowing_strategy_id:"w0@oDVZXSFIwa"}} windowing_strategies:{key:"w0@oDVZXSFIwa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oDVZXSFIwa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oDVZXSFIwa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oDVZXSFIwa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678566787623480938\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oDVZXSFIwa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000111e00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000111e00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6f20?, 0xc000131770?}, {0x113b38e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc0001270a0, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6ec0?, 0xc000131770?}, {0xc00004c540, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7fce4c72ab98?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001270a0, 0xf}, {0xc00004c540, 0x52}, {0xebcb40, 0xc0001aab50})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000642d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000642d00, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.454s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.027s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8ad001f5509aacbae0b017e86f583841fbb0321bcae7797478268ccd9e169f32
Deleted: sha256:a775ae493e6d514035b4e8e67554bc48054a305ea6e9265553a0fb579de3ad6a
Deleted: sha256:cb58fd6901c9890c15eaf8471c94161f6c142094f01c04608351c04694864380
Deleted: sha256:34f843bcd92cf5ed8a9df83b05ecd4824f3ff335ad75db93dfafc43b5f531af2
Deleted: sha256:d09cb450955aee152ac2dd8845d3bb762d2267fe7c34caee20ac52701de66a07
Deleted: sha256:e632d63d4e5241869ca01f6c810e9d850ed36ecb028b643bc6d0a9e3d7df2d7c
Deleted: sha256:6c58cffa73c390b0729d1910714c3207913c6778fde09c0080c419392450a5c2
Deleted: sha256:e901cee88b2a04045ccb862dcf3d8dbe002de21cbc7e75ad3e938c3cbf958173
Deleted: sha256:8b2571741e590ff7b2365678a8ec9b35687de77c4f9ed6216ab221cc70d22b36
Deleted: sha256:ba946a33234a338e4883650c671869c7e9c829510cd4f521fe79bf0f404cdd82
Deleted: sha256:d405a71f0d0a08b44a8539841d71af08d86e5f73ce2b99738291f2f2af9688fc
Deleted: sha256:12d8f9cb6926a203cf994cea9f65b4368bb55150843571a26db8e53a5508fb0c
Deleted: sha256:531a8ff6edfee354142c5a056829122db4a4682e4186d50e16cc6ccc08da696a
Deleted: sha256:78b0e2e6176f1516fa023816bc9c9a5348f7cba20b3b35cd5a9aaf37f382f563
Deleted: sha256:2f2bc0cf12224f4414d50ad6b590249837a0b16571359ff7dd08ce1992cf9bf5
Deleted: sha256:ba16ca2529bd2b24eeab243fb036694d72482dd912275b41c7627c0d6d4e85ac
Deleted: sha256:08f9f731e9869ef2a4d7ddf47d20bb3fa04df64bad6a9f93034959c6dcd92cf2
Deleted: sha256:b0a895d5a09bb55fe672ed8e1bffb96c97eb4724aba14e96fc2cf72b265362b1
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8ad001f5509aacbae0b017e86f583841fbb0321bcae7797478268ccd9e169f32
  Associated tags:
 - 20230311-203230
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-203230].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8ad001f5509aacbae0b017e86f583841fbb0321bcae7797478268ccd9e169f32].
$ rm -rf /tmp/tmp.hTkNRLms5b
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e789764031e22b100a2d6d2652d233d5ee9472e4a22e7e67ea8540acc435f052].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:96964bbd54c1bc7aa7701fbe2bb75ae14cfff68925df62df69fa61dbe7fb8e14].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3133606.
Stopping expansion service pid: 3133607.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 13s
232 actionable tasks: 179 executed, 43 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1389

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1389/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-143153",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311142042",
            "environmentId": "uNvYOjrpTMbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-143153"
      }
    ]
  },
  "name": "go-testxlang_partition-698",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/11 15:15:57 Submitted job: 2023-03-11_07_15_56-15005632805434650650
2023/03/11 15:15:57 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-11_07_15_56-15005632805434650650?project=apache-beam-testing
2023/03/11 15:15:57 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-11_07_15_56-15005632805434650650
2023/03/11 15:15:57 Job state: JOB_STATE_PENDING ...
2023/03/11 15:16:27 Job still running ...
2023/03/11 15:16:57 Job still running ...
2023/03/11 15:17:27 Job still running ...
2023/03/11 15:17:57 Job still running ...
2023/03/11 15:18:27 Job still running ...
2023/03/11 15:18:57 Job still running ...
2023/03/11 15:19:27 Job still running ...
2023/03/11 15:19:57 Job still running ...
2023/03/11 15:20:27 Job still running ...
2023/03/11 15:20:57 Job still running ...
2023/03/11 15:21:27 Job still running ...
2023/03/11 15:21:57 Job still running ...
2023/03/11 15:22:27 Job still running ...
2023/03/11 15:22:57 Job still running ...
2023/03/11 15:23:28 Job still running ...
2023/03/11 15:23:58 Job still running ...
2023/03/11 15:24:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-11_07_15_56-15005632805434650650 failed
--- FAIL: TestXLang_Partition (550.28s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3149.799s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678545151631160246
--- FAIL: TestBigQueryIO_BasicWriteRead (4.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40647 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nACELgbXoS" is_bounded:BOUNDED windowing_strategy_id:"w0@nACELgbXoS"}} windowing_strategies:{key:"w0@nACELgbXoS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nACELgbXoS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nACELgbXoS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nACELgbXoS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678545151631160246\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nACELgbXoS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40647 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@nACELgbXoS" is_bounded:BOUNDED windowing_strategy_id:"w0@nACELgbXoS"}} windowing_strategies:{key:"w0@nACELgbXoS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@nACELgbXoS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@nACELgbXoS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@nACELgbXoS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678545151631160246\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"nACELgbXoS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0001b3940})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0001b3940})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000400860?, 0xc000132000?}, {0x113b38e, 0x39}, {0xc0000ee0c0?, 0xa9e920?, 0x1?}, {0xc00041d000, 0xf}, 0xc000227d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004007c0?, 0xc000132000?}, {0xc0000e83c0, 0x52}, {0x1?}, {0xc000227ea8, 0x2, 0x7fb10c3d7a40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00041d000, 0xf}, {0xc0000e83c0, 0x52}, {0xebcb40, 0xc0005421d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102d00, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.495s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8597a2a11b920c65e1acf193da6be96b4cfac27320c5d928a64ce047105e0117
  Associated tags:
 - 20230311-143153
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-143153
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-143153].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8597a2a11b920c65e1acf193da6be96b4cfac27320c5d928a64ce047105e0117].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a7038aef4bd51f14194111411160ef08b7a6f24c71f78c54e45aa45fa310dd8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a7038aef4bd51f14194111411160ef08b7a6f24c71f78c54e45aa45fa310dd8])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a7038aef4bd51f14194111411160ef08b7a6f24c71f78c54e45aa45fa310dd8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a7038aef4bd51f14194111411160ef08b7a6f24c71f78c54e45aa45fa310dd8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8a2a091fe5f3799cc9038c9b846633163faaed63183b76af5618ce76e0f168c7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8a2a091fe5f3799cc9038c9b846633163faaed63183b76af5618ce76e0f168c7])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8a2a091fe5f3799cc9038c9b846633163faaed63183b76af5618ce76e0f168c7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8a2a091fe5f3799cc9038c9b846633163faaed63183b76af5618ce76e0f168c7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 43s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1388

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1388/display/redirect>

Changes:


------------------------------------------
[...truncated 585.96 KB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311082028",
            "environmentId": "ZDJywwqqgUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231"
      }
    ]
  },
  "name": "go-testxlang_partition-948",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/11 09:17:30 Submitted job: 2023-03-11_01_17_30-5424893049123362009
2023/03/11 09:17:30 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-11_01_17_30-5424893049123362009?project=apache-beam-testing
2023/03/11 09:17:30 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-11_01_17_30-5424893049123362009
2023/03/11 09:17:30 Job state: JOB_STATE_PENDING ...
2023/03/11 09:18:00 Job still running ...
2023/03/11 09:18:30 Job still running ...
2023/03/11 09:19:00 Job still running ...
2023/03/11 09:19:30 Job still running ...
2023/03/11 09:20:01 Job still running ...
2023/03/11 09:20:31 Job still running ...
2023/03/11 09:21:01 Job still running ...
2023/03/11 09:21:31 Job still running ...
2023/03/11 09:22:01 Job still running ...
2023/03/11 09:22:31 Job still running ...
2023/03/11 09:23:01 Job still running ...
2023/03/11 09:23:31 Job still running ...
2023/03/11 09:24:01 Job still running ...
2023/03/11 09:24:31 Job still running ...
2023/03/11 09:25:01 Job still running ...
2023/03/11 09:25:31 Job still running ...
2023/03/11 09:26:01 Job still running ...
2023/03/11 09:26:31 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-11_01_17_30-5424893049123362009 failed
--- FAIL: TestXLang_Partition (580.92s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3238.042s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678523587271318193
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36963 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@krtqzLiKSK" is_bounded:BOUNDED windowing_strategy_id:"w0@krtqzLiKSK"}} windowing_strategies:{key:"w0@krtqzLiKSK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@krtqzLiKSK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@krtqzLiKSK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@krtqzLiKSK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678523587271318193\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"krtqzLiKSK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36963 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@krtqzLiKSK" is_bounded:BOUNDED windowing_strategy_id:"w0@krtqzLiKSK"}} windowing_strategies:{key:"w0@krtqzLiKSK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@krtqzLiKSK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@krtqzLiKSK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@krtqzLiKSK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678523587271318193\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"krtqzLiKSK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000612f00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000612f00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6cc0?, 0xc000117680?}, {0x113b38e, 0x39}, {0xc0001d20c0?, 0xa9e920?, 0x1?}, {0xc000042d40, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6c60?, 0xc000117680?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f63a6b4bc20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d40, 0xf}, {0xc00004c4e0, 0x52}, {0xebcb40, 0xc0001a8170})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006029c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006029c0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.356s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:141f5e50db31669fd12bd04d99f71377e3699df1e7c6b0fb4938aba82f203ade
Deleted: sha256:b1cac1fb222929b55513e24ae0ce2fb5a1c445ce0d793895bf4edefa69eb5314
Deleted: sha256:1f5d4d93d6c261fe105f1b6e4be39ef14aaea3b5b7051674053a11545c9712b6
Deleted: sha256:3ab677f4aab94739cc137b09eceaa301460ca277e9eb8c108076a953942715ca
Deleted: sha256:f6e6b2ea81b5d4baebc11d26fb9fb84b5334980c1e5a0cc9f22edb7e1674c02b
Deleted: sha256:7173e5afb012402c3fa61868a3932931a1de7cac4833172ffd9be5d8b7485dde
Deleted: sha256:810a2c27e80b26f13222ec61de0698e37e0a4628ef7b908a890e0c5659c8228b
Deleted: sha256:3bf3ed1c19b14cdee4dee966e2f4df191412b78036584b7cce747a93e2c695ca
Deleted: sha256:7f890c9acac8592c024b991a386276839b632366bcae40bc9351bc08743cd5da
Deleted: sha256:977ec7f61bc68a03faf600c7e2dd5171fb1c6d73b40b539cbc9e63e09090a423
Deleted: sha256:70b9c9fcafcc22112acdb0f16aefcb423fed149069e83803eac40aed921c50e5
Deleted: sha256:5ccdb60647837e7e366604cb4ccca0da35e86adbd5b994381c99c881e49ed9ee
Deleted: sha256:6f342d860e61f135e5ba8f8ef4188c403866a463caeb80bbe057e94623bcea60
Deleted: sha256:85cfb00bb4c1a2d03047b114bf466315015f06e6d98c85b9c0bed6f3b3118dcd
Deleted: sha256:f06df298011138e831490d547bcd225329a77e89f1a4e0c2c56d39be3b9d6834
Deleted: sha256:20b18f48f33abe6386beace41b7933efe85c9047cc9958e9bc54064ebb34ecd8
Deleted: sha256:4921efd7f788abf4d13eec64b1a77beb0919790608424ef11f7927faac203315
Deleted: sha256:d81832ef1f10e176039902efc9f1e4d943c6cc3965730cac8c949fd3fa5b9bf8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:141f5e50db31669fd12bd04d99f71377e3699df1e7c6b0fb4938aba82f203ade
  Associated tags:
 - 20230311-083231
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-083231].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:141f5e50db31669fd12bd04d99f71377e3699df1e7c6b0fb4938aba82f203ade].
$ rm -rf /tmp/tmp.szCX7oPchc
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311082028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:533b03c0651807f23f102778058a5daf2c00cfe3654312dca53bfba2a9457dfd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311082028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:745432adbc21b53e1b324b43a318ec6584dfb784138920d399a76ec52ef07d59].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2715179.
Stopping expansion service pid: 2715180.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 1s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1387

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1387/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-023221",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311022030",
            "environmentId": "oDzQqSzUxSbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-023221"
      }
    ]
  },
  "name": "go-testxlang_partition-58",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/11 03:16:23 Submitted job: 2023-03-10_19_16_23-10673749517763266182
2023/03/11 03:16:23 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-10_19_16_23-10673749517763266182?project=apache-beam-testing
2023/03/11 03:16:23 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-10_19_16_23-10673749517763266182
2023/03/11 03:16:23 Job state: JOB_STATE_PENDING ...
2023/03/11 03:16:54 Job still running ...
2023/03/11 03:17:24 Job still running ...
2023/03/11 03:17:54 Job still running ...
2023/03/11 03:18:24 Job still running ...
2023/03/11 03:18:54 Job still running ...
2023/03/11 03:19:24 Job still running ...
2023/03/11 03:19:54 Job still running ...
2023/03/11 03:20:24 Job still running ...
2023/03/11 03:20:54 Job still running ...
2023/03/11 03:21:24 Job still running ...
2023/03/11 03:21:54 Job still running ...
2023/03/11 03:22:24 Job still running ...
2023/03/11 03:22:54 Job still running ...
2023/03/11 03:23:24 Job still running ...
2023/03/11 03:23:54 Job still running ...
2023/03/11 03:24:24 Job still running ...
2023/03/11 03:24:54 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-10_19_16_23-10673749517763266182 failed
--- FAIL: TestXLang_Partition (550.61s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3147.933s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678501980290699662
--- FAIL: TestBigQueryIO_BasicWriteRead (5.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40921 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KFrJITOyCb" is_bounded:BOUNDED windowing_strategy_id:"w0@KFrJITOyCb"}} windowing_strategies:{key:"w0@KFrJITOyCb" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KFrJITOyCb" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KFrJITOyCb" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KFrJITOyCb" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678501980290699662\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KFrJITOyCb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40921 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KFrJITOyCb" is_bounded:BOUNDED windowing_strategy_id:"w0@KFrJITOyCb"}} windowing_strategies:{key:"w0@KFrJITOyCb" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KFrJITOyCb" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KFrJITOyCb" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KFrJITOyCb" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678501980290699662\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KFrJITOyCb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000459240})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000459240})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168fa0?, 0xc000418000?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000802d20, 0xf}, 0xc0004f9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168f40?, 0xc000418000?}, {0xc0008263c0, 0x52}, {0x1?}, {0xc0004f9ea8, 0x2, 0x7fa1c9b19238?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000802d20, 0xf}, {0xc0008263c0, 0x52}, {0xebcb40, 0xc00048c180})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00053d1e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00053d1e0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.870s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.047s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9d29f178e001257da00b5b41cad1a97958a5446747c34b3ebba0903acae80ae5
  Associated tags:
 - 20230311-023221
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-023221
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230311-023221].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9d29f178e001257da00b5b41cad1a97958a5446747c34b3ebba0903acae80ae5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:01424327c8230b4b40e06d97edb1aea93882f71564a69218ff1f15e9fef79b02]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230311022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:01424327c8230b4b40e06d97edb1aea93882f71564a69218ff1f15e9fef79b02])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:01424327c8230b4b40e06d97edb1aea93882f71564a69218ff1f15e9fef79b02
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:01424327c8230b4b40e06d97edb1aea93882f71564a69218ff1f15e9fef79b02].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5156dbf37a859dc4e0a1f8fba6b20355f4a6b4ba421f9b4b694db78abc56f5c4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230311022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5156dbf37a859dc4e0a1f8fba6b20355f4a6b4ba421f9b4b694db78abc56f5c4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5156dbf37a859dc4e0a1f8fba6b20355f4a6b4ba421f9b4b694db78abc56f5c4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5156dbf37a859dc4e0a1f8fba6b20355f4a6b4ba421f9b4b694db78abc56f5c4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 21s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1386

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1386/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729"
      }
    ]
  },
  "name": "go-testxlang_partition-105",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/10 21:52:14 Submitted job: 2023-03-10_13_52_13-8964979915047115035
2023/03/10 21:52:14 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-10_13_52_13-8964979915047115035?project=apache-beam-testing
2023/03/10 21:52:14 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-10_13_52_13-8964979915047115035
2023/03/10 21:52:14 Job state: JOB_STATE_PENDING ...
2023/03/10 21:52:44 Job still running ...
2023/03/10 21:53:14 Job still running ...
2023/03/10 21:53:44 Job still running ...
2023/03/10 21:54:14 Job still running ...
2023/03/10 21:54:44 Job still running ...
2023/03/10 21:55:14 Job still running ...
2023/03/10 21:55:44 Job still running ...
2023/03/10 21:56:14 Job still running ...
2023/03/10 21:56:45 Job still running ...
2023/03/10 21:57:15 Job still running ...
2023/03/10 21:57:45 Job still running ...
2023/03/10 21:58:15 Job still running ...
2023/03/10 21:58:45 Job still running ...
2023/03/10 21:59:15 Job still running ...
2023/03/10 21:59:45 Job still running ...
2023/03/10 22:00:15 Job still running ...
2023/03/10 22:00:45 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-10_13_52_13-8964979915047115035 failed
--- FAIL: TestXLang_Partition (551.15s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3186.625s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678482498255882532
--- FAIL: TestBigQueryIO_BasicWriteRead (4.87s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34853 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@IBxCMfnSQI" is_bounded:BOUNDED windowing_strategy_id:"w0@IBxCMfnSQI"}} windowing_strategies:{key:"w0@IBxCMfnSQI" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@IBxCMfnSQI" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@IBxCMfnSQI" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@IBxCMfnSQI" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678482498255882532\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"IBxCMfnSQI"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34853 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@IBxCMfnSQI" is_bounded:BOUNDED windowing_strategy_id:"w0@IBxCMfnSQI"}} windowing_strategies:{key:"w0@IBxCMfnSQI" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@IBxCMfnSQI" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@IBxCMfnSQI" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@IBxCMfnSQI" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678482498255882532\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"IBxCMfnSQI"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0000b0b00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0000b0b00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00040c8c0?, 0xc00043d630?}, {0x113b38e, 0x39}, {0xc0000f0180?, 0xa9e920?, 0x1?}, {0xc00040ab80, 0xf}, 0xc00055fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00040c860?, 0xc00043d630?}, {0xc000136420, 0x52}, {0x1?}, {0xc00055fea8, 0x2, 0x7f114a168240?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00040ab80, 0xf}, {0xc000136420, 0x52}, {0xebcb40, 0xc00040bea0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00041eea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00041eea0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.912s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bda0ba777b1cc4c432d2b853cbc7868266ca1ba430045648cb12f790d0ea8853
Deleted: sha256:b3dfcdf003b99d174209c62ff221bb6df9a88f9e84150dc5acbad9f92aa010db
Deleted: sha256:68da2096d2e7ad0fe99828b4fc5ec2326baeb34fd14d2b0335fac3afd0a8b114
Deleted: sha256:1c8415e8421d82d28931e51d9703701b2223729d7e0bbf198dc8f8e3437d4a8c
Deleted: sha256:d7fa28445e46a6f3714dc419e016f20a23ee04e474657b1f02e5d347630675f6
Deleted: sha256:f1d5932d2916fc66908390f263cb70c0411000f781abb4cdc9de8ca256fec968
Deleted: sha256:b2f15dab3614c90ca0114c3646d6bd8563d54f9e3887191f1ed772ba9ca91708
Deleted: sha256:ac49c36fedbccaae8b67c96e8a437feaa7624a6372924f82d228df665ffb7a47
Deleted: sha256:303717836b351a7207e64cc0da4fcf939457f05510fd3caec7407863448ab29e
Deleted: sha256:dcefa45274c7d9203809420e60024c707a39653817d6dc97d3e798e009d034fc
Deleted: sha256:e061b2b4a4c49273e3b0a5dfc5da33fa5b73f5762d96796f4414ab1bc9a413e6
Deleted: sha256:7e0ee3b1e954e75cc13581ed7f9af43f55c759209f4e37abdbe552292ad85d9a
Deleted: sha256:48b1b331e504d98492d4c97489c4860544484adb2a2b435a49a24dde5f686414
Deleted: sha256:1f90302cc9448a3dc264b905f2fb736091fbf2321df07304a842440946e7d3e1
Deleted: sha256:8074edb5607f4ebac144ec2ad38c292e86bea268afffb57ae1053071fca7cc39
Deleted: sha256:03d4d62e6e90881c074fcd0d45809ef8dd4cc108ca47505103f562e06bd3f59f
Deleted: sha256:28658d7f2122bd0ce577c3727ec589bdd3549b6e50310e8e280194bfc699c84a
Deleted: sha256:cd1f7f6ed37bbb92a8fe4d7e6a087e309ef80dc2785e08e560ff24ab6ded5a6e
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bda0ba777b1cc4c432d2b853cbc7868266ca1ba430045648cb12f790d0ea8853
  Associated tags:
 - 20230310-210729
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-210729].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bda0ba777b1cc4c432d2b853cbc7868266ca1ba430045648cb12f790d0ea8853].
$ rm -rf /tmp/tmp.UIOn7C0IMe
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310205426
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310205426]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310205426] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5d0d8d3492ce7c1ddb3c916d125d261bffb9ec6da4616137020cc7da84ac945e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310205426
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310205426]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310205426] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1a4223253b2840938993a1ccc8e3d82e6eabda227f453d81409ae6202564b634].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1737203.
Stopping expansion service pid: 1737204.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 25s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1385

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1385/display/redirect?page=changes>

Changes:

[noreply] adding cache expire for example catalog (#25760)


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310142040",
            "environmentId": "DTVQzqyPjRbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-143211",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-143211"
      }
    ]
  },
  "name": "go-testxlang_partition-341",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/10 15:14:52 Submitted job: 2023-03-10_07_14_51-12920238030731813221
2023/03/10 15:14:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-10_07_14_51-12920238030731813221?project=apache-beam-testing
2023/03/10 15:14:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-10_07_14_51-12920238030731813221
2023/03/10 15:14:52 Job state: JOB_STATE_PENDING ...
2023/03/10 15:15:22 Job still running ...
2023/03/10 15:15:52 Job still running ...
2023/03/10 15:16:22 Job still running ...
2023/03/10 15:16:52 Job still running ...
2023/03/10 15:17:22 Job still running ...
2023/03/10 15:17:52 Job still running ...
2023/03/10 15:18:22 Job still running ...
2023/03/10 15:18:52 Job still running ...
2023/03/10 15:19:22 Job still running ...
2023/03/10 15:19:53 Job still running ...
2023/03/10 15:20:23 Job still running ...
2023/03/10 15:20:53 Job still running ...
2023/03/10 15:21:23 Job still running ...
2023/03/10 15:21:53 Job still running ...
2023/03/10 15:22:23 Job still running ...
2023/03/10 15:22:53 Job still running ...
2023/03/10 15:23:23 Job still running ...
2023/03/10 15:23:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-10_07_14_51-12920238030731813221 failed
--- FAIL: TestXLang_Partition (581.64s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3097.264s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678458769394810931
--- FAIL: TestBigQueryIO_BasicWriteRead (4.69s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39701 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KcHtSJmRUo" is_bounded:BOUNDED windowing_strategy_id:"w0@KcHtSJmRUo"}} windowing_strategies:{key:"w0@KcHtSJmRUo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KcHtSJmRUo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KcHtSJmRUo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KcHtSJmRUo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678458769394810931\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KcHtSJmRUo"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39701 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KcHtSJmRUo" is_bounded:BOUNDED windowing_strategy_id:"w0@KcHtSJmRUo"}} windowing_strategies:{key:"w0@KcHtSJmRUo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KcHtSJmRUo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KcHtSJmRUo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KcHtSJmRUo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678458769394810931\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KcHtSJmRUo"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000461280})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000461280})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000650680?, 0xc000492050?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc000042c60, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000650620?, 0xc000492050?}, {0xc000444360, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0xe7b800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042c60, 0xf}, {0xc000444360, 0x52}, {0xebcb40, 0xc0004941a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003164e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003164e0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.721s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1fd439cd33ff695d730614ef123ed20149bcd0b0591a1be452c45e269134a9e6
  Associated tags:
 - 20230310-143211
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-143211
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-143211].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1fd439cd33ff695d730614ef123ed20149bcd0b0591a1be452c45e269134a9e6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310142040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0806e8899b43b4705ff8dd6fcf4152659407918e83d9a5cabab24bb217dee485]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310142040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0806e8899b43b4705ff8dd6fcf4152659407918e83d9a5cabab24bb217dee485])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0806e8899b43b4705ff8dd6fcf4152659407918e83d9a5cabab24bb217dee485
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0806e8899b43b4705ff8dd6fcf4152659407918e83d9a5cabab24bb217dee485].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310142040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:764d885456cc43a1a4463de90a6e615c155159f7cb20d6098b79411a066a54ad]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310142040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:764d885456cc43a1a4463de90a6e615c155159f7cb20d6098b79411a066a54ad])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:764d885456cc43a1a4463de90a6e615c155159f7cb20d6098b79411a066a54ad
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:764d885456cc43a1a4463de90a6e615c155159f7cb20d6098b79411a066a54ad].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 9s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1384

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1384/display/redirect>

Changes:


------------------------------------------
[...truncated 536.71 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-083205",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310082028",
            "environmentId": "DjZEOJkNNmbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-083205"
      }
    ]
  },
  "name": "go-testxlang_partition-392",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/10 09:17:54 Submitted job: 2023-03-10_01_17_54-1915310220049721002
2023/03/10 09:17:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-10_01_17_54-1915310220049721002?project=apache-beam-testing
2023/03/10 09:17:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-10_01_17_54-1915310220049721002
2023/03/10 09:17:54 Job state: JOB_STATE_PENDING ...
2023/03/10 09:18:24 Job still running ...
2023/03/10 09:18:54 Job still running ...
2023/03/10 09:19:24 Job still running ...
2023/03/10 09:19:54 Job still running ...
2023/03/10 09:20:24 Job still running ...
2023/03/10 09:20:55 Job still running ...
2023/03/10 09:21:25 Job still running ...
2023/03/10 09:21:55 Job still running ...
2023/03/10 09:22:25 Job still running ...
2023/03/10 09:22:55 Job still running ...
2023/03/10 09:23:25 Job still running ...
2023/03/10 09:23:55 Job still running ...
2023/03/10 09:24:25 Job still running ...
2023/03/10 09:24:55 Job still running ...
2023/03/10 09:25:25 Job still running ...
2023/03/10 09:25:55 Job still running ...
2023/03/10 09:26:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-10_01_17_54-1915310220049721002 failed
--- FAIL: TestXLang_Partition (550.61s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3256.318s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678437162611680743
--- FAIL: TestBigQueryIO_BasicWriteRead (4.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42485 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZBTsbQYIcc" is_bounded:BOUNDED windowing_strategy_id:"w0@ZBTsbQYIcc"}} windowing_strategies:{key:"w0@ZBTsbQYIcc" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZBTsbQYIcc" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZBTsbQYIcc" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZBTsbQYIcc" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678437162611680743\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZBTsbQYIcc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42485 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZBTsbQYIcc" is_bounded:BOUNDED windowing_strategy_id:"w0@ZBTsbQYIcc"}} windowing_strategies:{key:"w0@ZBTsbQYIcc" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZBTsbQYIcc" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZBTsbQYIcc" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZBTsbQYIcc" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678437162611680743\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZBTsbQYIcc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc0005ce980})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc0005ce980})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169680?, 0xc0001399f0?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc00032ad60, 0xf}, 0xc0006abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169620?, 0xc0001399f0?}, {0xc00010e8a0, 0x52}, {0x1?}, {0xc0006abea8, 0x2, 0x7efd43527cb0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00032ad60, 0xf}, {0xc00010e8a0, 0x52}, {0xebcb40, 0xc0006bc070})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000589380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000589380, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.485s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5b1df01ece3eaa71945dd72010dc921023d9f2270edea74fdb7a462ce3704895
  Associated tags:
 - 20230310-083205
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-083205
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-083205].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5b1df01ece3eaa71945dd72010dc921023d9f2270edea74fdb7a462ce3704895].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2f13bdf49fef8256dd1ff51449ee623ec9162a785a9941e017d49c744a1d415a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2f13bdf49fef8256dd1ff51449ee623ec9162a785a9941e017d49c744a1d415a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2f13bdf49fef8256dd1ff51449ee623ec9162a785a9941e017d49c744a1d415a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2f13bdf49fef8256dd1ff51449ee623ec9162a785a9941e017d49c744a1d415a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a7d8acc3ec7aaed2be624f8a89004354d8a7802d6cf2135ac55e748317f4c22a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a7d8acc3ec7aaed2be624f8a89004354d8a7802d6cf2135ac55e748317f4c22a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a7d8acc3ec7aaed2be624f8a89004354d8a7802d6cf2135ac55e748317f4c22a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a7d8acc3ec7aaed2be624f8a89004354d8a7802d6cf2135ac55e748317f4c22a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 54s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1383

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1383/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-023225",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310022039",
            "environmentId": "uvqQRIARCMbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-023225"
      }
    ]
  },
  "name": "go-testxlang_partition-5",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/10 03:17:33 Submitted job: 2023-03-09_19_17_33-226728666840682960
2023/03/10 03:17:33 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-09_19_17_33-226728666840682960?project=apache-beam-testing
2023/03/10 03:17:33 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-09_19_17_33-226728666840682960
2023/03/10 03:17:33 Job state: JOB_STATE_PENDING ...
2023/03/10 03:18:03 Job still running ...
2023/03/10 03:18:33 Job still running ...
2023/03/10 03:19:03 Job still running ...
2023/03/10 03:19:33 Job still running ...
2023/03/10 03:20:03 Job still running ...
2023/03/10 03:20:33 Job still running ...
2023/03/10 03:21:03 Job still running ...
2023/03/10 03:21:33 Job still running ...
2023/03/10 03:22:03 Job still running ...
2023/03/10 03:22:34 Job still running ...
2023/03/10 03:23:04 Job still running ...
2023/03/10 03:23:34 Job still running ...
2023/03/10 03:24:04 Job still running ...
2023/03/10 03:24:34 Job still running ...
2023/03/10 03:25:04 Job still running ...
2023/03/10 03:25:34 Job still running ...
2023/03/10 03:26:04 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-09_19_17_33-226728666840682960 failed
--- FAIL: TestXLang_Partition (550.91s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3213.182s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678415584690119223
--- FAIL: TestBigQueryIO_BasicWriteRead (4.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46251 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mYgGOtvFfi" is_bounded:BOUNDED windowing_strategy_id:"w0@mYgGOtvFfi"}} windowing_strategies:{key:"w0@mYgGOtvFfi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mYgGOtvFfi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mYgGOtvFfi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mYgGOtvFfi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678415584690119223\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mYgGOtvFfi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46251 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mYgGOtvFfi" is_bounded:BOUNDED windowing_strategy_id:"w0@mYgGOtvFfi"}} windowing_strategies:{key:"w0@mYgGOtvFfi" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mYgGOtvFfi" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mYgGOtvFfi" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mYgGOtvFfi" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678415584690119223\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mYgGOtvFfi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000430b00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000430b00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005a68a0?, 0xc0000bd680?}, {0x113b38e, 0x39}, {0xc00015a0c0?, 0xa9e920?, 0x1?}, {0xc00042ec50, 0xf}, 0xc0006f9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005a6840?, 0xc0000bd680?}, {0xc0006d4300, 0x52}, {0x1?}, {0xc0006f9ea8, 0x2, 0x7f0a7c087b08?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00042ec50, 0xf}, {0xc0006d4300, 0x52}, {0xebcb40, 0xc00042ff60})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0006c29c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0006c29c0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.492s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9425e279777602822581d004570dc1205e4e0250a9659ae307286d3764a9615
  Associated tags:
 - 20230310-023225
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-023225
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230310-023225].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9425e279777602822581d004570dc1205e4e0250a9659ae307286d3764a9615].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310022039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35fa4e27faae85b0c81ac8eaf7f1396ae7ffdfc613df4837e55a94fc4e4cb079]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230310022039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35fa4e27faae85b0c81ac8eaf7f1396ae7ffdfc613df4837e55a94fc4e4cb079])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35fa4e27faae85b0c81ac8eaf7f1396ae7ffdfc613df4837e55a94fc4e4cb079
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35fa4e27faae85b0c81ac8eaf7f1396ae7ffdfc613df4837e55a94fc4e4cb079].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310022039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6f1e4bdef9b28c8f887c1d721a8b243e0a35def3ace7116b49446a522a225c3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230310022039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6f1e4bdef9b28c8f887c1d721a8b243e0a35def3ace7116b49446a522a225c3])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6f1e4bdef9b28c8f887c1d721a8b243e0a35def3ace7116b49446a522a225c3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b6f1e4bdef9b28c8f887c1d721a8b243e0a35def3ace7116b49446a522a225c3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 23s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1382

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1382/display/redirect>

Changes:


------------------------------------------
[...truncated 574.88 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-203426",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309202032",
            "environmentId": "KwEHctevAbbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-203426"
      }
    ]
  },
  "name": "go-testxlang_partition-930",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/09 21:29:40 Submitted job: 2023-03-09_13_29_40-1139310099241626337
2023/03/09 21:29:40 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-09_13_29_40-1139310099241626337?project=apache-beam-testing
2023/03/09 21:29:40 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-09_13_29_40-1139310099241626337
2023/03/09 21:29:40 Job state: JOB_STATE_PENDING ...
2023/03/09 21:30:10 Job still running ...
2023/03/09 21:30:40 Job still running ...
2023/03/09 21:31:11 Job still running ...
2023/03/09 21:31:41 Job still running ...
2023/03/09 21:32:11 Job still running ...
2023/03/09 21:32:41 Job still running ...
2023/03/09 21:33:11 Job still running ...
2023/03/09 21:33:41 Job still running ...
2023/03/09 21:34:11 Job still running ...
2023/03/09 21:34:41 Job still running ...
2023/03/09 21:35:11 Job still running ...
2023/03/09 21:35:41 Job still running ...
2023/03/09 21:36:11 Job still running ...
2023/03/09 21:36:41 Job still running ...
2023/03/09 21:37:11 Job still running ...
2023/03/09 21:37:42 Job still running ...
2023/03/09 21:38:12 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-09_13_29_40-1139310099241626337 failed
--- FAIL: TestXLang_Partition (551.09s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3812.990s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678394118595756961
--- FAIL: TestBigQueryIO_BasicWriteRead (4.76s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39993 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@JPHbJvxgaG" is_bounded:BOUNDED windowing_strategy_id:"w0@JPHbJvxgaG"}} windowing_strategies:{key:"w0@JPHbJvxgaG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@JPHbJvxgaG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@JPHbJvxgaG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@JPHbJvxgaG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678394118595756961\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"JPHbJvxgaG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39993 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@JPHbJvxgaG" is_bounded:BOUNDED windowing_strategy_id:"w0@JPHbJvxgaG"}} windowing_strategies:{key:"w0@JPHbJvxgaG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@JPHbJvxgaG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@JPHbJvxgaG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@JPHbJvxgaG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678394118595756961\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"JPHbJvxgaG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf6ef40, 0xc000704bc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6ef40, 0xc000704bc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004006e0?, 0xc0000ba280?}, {0x113b38e, 0x39}, {0xc00066a000?, 0xa9e920?, 0x1?}, {0xc000708070, 0xf}, 0xc000199d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000400680?, 0xc0000ba280?}, {0xc00004c8a0, 0x52}, {0x1?}, {0xc000199ea8, 0x2, 0x7fd92f126450?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000708070, 0xf}, {0xc00004c8a0, 0x52}, {0xebcb40, 0xc0003100f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001024e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001024e0, 0x116d330)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.820s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e5ba03341721cf1871985befc3b8b4f80acba706df78a02d2d4733ddb0bd995b
  Associated tags:
 - 20230309-203426
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-203426
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-203426].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e5ba03341721cf1871985befc3b8b4f80acba706df78a02d2d4733ddb0bd995b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a25ee61a0d03a7b3a3ba519626d25e5416947ba5bab3d2130bbdaf094ece46d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a25ee61a0d03a7b3a3ba519626d25e5416947ba5bab3d2130bbdaf094ece46d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a25ee61a0d03a7b3a3ba519626d25e5416947ba5bab3d2130bbdaf094ece46d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0a25ee61a0d03a7b3a3ba519626d25e5416947ba5bab3d2130bbdaf094ece46d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50eb1cd2b660dcdcbca352b125f75dc7e0b9cd777344bc5716de0b9d42834d56]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50eb1cd2b660dcdcbca352b125f75dc7e0b9cd777344bc5716de0b9d42834d56])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50eb1cd2b660dcdcbca352b125f75dc7e0b9cd777344bc5716de0b9d42834d56
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50eb1cd2b660dcdcbca352b125f75dc7e0b9cd777344bc5716de0b9d42834d56].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 18m 40s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1381

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1381/display/redirect>

Changes:


------------------------------------------
[...truncated 1021.17 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-143304",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309142042",
            "environmentId": "HnNgfhENcgbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-143304"
      }
    ]
  },
  "name": "go-testxlang_partition-604",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/09 15:17:15 Submitted job: 2023-03-09_07_17_14-15374542330002633502
2023/03/09 15:17:15 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-09_07_17_14-15374542330002633502?project=apache-beam-testing
2023/03/09 15:17:15 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-09_07_17_14-15374542330002633502
2023/03/09 15:17:15 Job state: JOB_STATE_PENDING ...
2023/03/09 15:17:45 Job still running ...
2023/03/09 15:18:15 Job still running ...
2023/03/09 15:18:45 Job still running ...
2023/03/09 15:19:15 Job still running ...
2023/03/09 15:19:45 Job still running ...
2023/03/09 15:20:15 Job still running ...
2023/03/09 15:20:45 Job still running ...
2023/03/09 15:21:15 Job still running ...
2023/03/09 15:21:45 Job still running ...
2023/03/09 15:22:15 Job still running ...
2023/03/09 15:22:46 Job still running ...
2023/03/09 15:23:16 Job still running ...
2023/03/09 15:23:46 Job still running ...
2023/03/09 15:24:16 Job still running ...
2023/03/09 15:24:46 Job still running ...
2023/03/09 15:25:16 Job still running ...
2023/03/09 15:25:46 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-09_07_17_14-15374542330002633502 failed
--- FAIL: TestXLang_Partition (551.57s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3147.162s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678372432601137287
--- FAIL: TestBigQueryIO_BasicWriteRead (4.92s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35327 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gKqfrQcSFO"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gKqfrQcSFO"}}  windowing_strategies:{key:"w0@gKqfrQcSFO"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gKqfrQcSFO"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gKqfrQcSFO"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gKqfrQcSFO"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678372432601137287\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gKqfrQcSFO"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35327 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gKqfrQcSFO"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gKqfrQcSFO"}}  windowing_strategies:{key:"w0@gKqfrQcSFO"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gKqfrQcSFO"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gKqfrQcSFO"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gKqfrQcSFO"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678372432601137287\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gKqfrQcSFO"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 37 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc000121440})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc000121440})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0006a0720?, 0xc0005b0000?}, {0x11384d6, 0x39}, {0xc0005b60c0?, 0xa9cba0?, 0x1?}, {0xc00049ace0, 0xf}, 0xc00002dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0006a06c0?, 0xc0005b0000?}, {0xc0004b6300, 0x52}, {0x1?}, {0xc00002dea8, 0x2, 0x7f22dc2b4eb8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00049ace0, 0xf}, {0xc0004b6300, 0x52}, {0xeba6e0, 0xc0006921d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00048aea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00048aea0, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.957s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.052s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68664e1848eb6fc874b3fa8cf7b5f9caf6c2e48e3e84a5a8c37a395335861f44
  Associated tags:
 - 20230309-143304
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-143304
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-143304].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:68664e1848eb6fc874b3fa8cf7b5f9caf6c2e48e3e84a5a8c37a395335861f44].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89fa66c7ef045d049b92699fa6b9d54931566c2bcb3c5792002ab8078b11275a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89fa66c7ef045d049b92699fa6b9d54931566c2bcb3c5792002ab8078b11275a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89fa66c7ef045d049b92699fa6b9d54931566c2bcb3c5792002ab8078b11275a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89fa66c7ef045d049b92699fa6b9d54931566c2bcb3c5792002ab8078b11275a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309142042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6364af5da00377f5a767825fb5eecf7dbbe8acf95c7ac68b4fc1bcd1b968d2b2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309142042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6364af5da00377f5a767825fb5eecf7dbbe8acf95c7ac68b4fc1bcd1b968d2b2])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6364af5da00377f5a767825fb5eecf7dbbe8acf95c7ac68b4fc1bcd1b968d2b2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6364af5da00377f5a767825fb5eecf7dbbe8acf95c7ac68b4fc1bcd1b968d2b2].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1380

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1380/display/redirect>

Changes:


------------------------------------------
[...truncated 567.94 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-083247",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309082043",
            "environmentId": "apgAVBrgQCbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-083247"
      }
    ]
  },
  "name": "go-testxlang_partition-962",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/09 09:17:19 Submitted job: 2023-03-09_01_17_19-15748873074679434446
2023/03/09 09:17:19 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-09_01_17_19-15748873074679434446?project=apache-beam-testing
2023/03/09 09:17:19 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-09_01_17_19-15748873074679434446
2023/03/09 09:17:19 Job state: JOB_STATE_PENDING ...
2023/03/09 09:17:49 Job still running ...
2023/03/09 09:18:19 Job still running ...
2023/03/09 09:18:49 Job still running ...
2023/03/09 09:19:19 Job still running ...
2023/03/09 09:19:49 Job still running ...
2023/03/09 09:20:19 Job still running ...
2023/03/09 09:20:49 Job still running ...
2023/03/09 09:21:19 Job still running ...
2023/03/09 09:21:49 Job still running ...
2023/03/09 09:22:20 Job still running ...
2023/03/09 09:22:50 Job still running ...
2023/03/09 09:23:20 Job still running ...
2023/03/09 09:23:50 Job still running ...
2023/03/09 09:24:20 Job still running ...
2023/03/09 09:24:50 Job still running ...
2023/03/09 09:25:20 Job still running ...
2023/03/09 09:25:50 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-09_01_17_19-15748873074679434446 failed
--- FAIL: TestXLang_Partition (550.73s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3179.168s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678350804340456252
--- FAIL: TestBigQueryIO_BasicWriteRead (4.41s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33341 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PkEkgoLYwc"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PkEkgoLYwc"}}  windowing_strategies:{key:"w0@PkEkgoLYwc"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PkEkgoLYwc"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PkEkgoLYwc"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PkEkgoLYwc"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678350804340456252\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PkEkgoLYwc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33341 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PkEkgoLYwc"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PkEkgoLYwc"}}  windowing_strategies:{key:"w0@PkEkgoLYwc"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PkEkgoLYwc"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PkEkgoLYwc"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PkEkgoLYwc"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678350804340456252\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PkEkgoLYwc"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc0000ce540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc0000ce540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048a5a0?, 0xc000494050?}, {0x11384d6, 0x39}, {0xc000542000?, 0xa9cba0?, 0x1?}, {0xc000043af0, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048a540?, 0xc000494050?}, {0xc00004c900, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f0a495dae10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043af0, 0xf}, {0xc00004c900, 0x52}, {0xeba6e0, 0xc0003f6110})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cb040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cb040, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.444s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fb5a6b0faeb9d7295c98d80ece63e69d4dfd601a2fd1b91e434c588d903f8352
  Associated tags:
 - 20230309-083247
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-083247
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-083247].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fb5a6b0faeb9d7295c98d80ece63e69d4dfd601a2fd1b91e434c588d903f8352].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f3149c0f2407e53f6cfbb5338ca5504204506328ff96f3102ce0777940e8d6d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f3149c0f2407e53f6cfbb5338ca5504204506328ff96f3102ce0777940e8d6d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f3149c0f2407e53f6cfbb5338ca5504204506328ff96f3102ce0777940e8d6d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6f3149c0f2407e53f6cfbb5338ca5504204506328ff96f3102ce0777940e8d6d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:928be855afc6d08aa10851973ffc4577b1b71c2a2927a41beacd6db8e2d34f8f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:928be855afc6d08aa10851973ffc4577b1b71c2a2927a41beacd6db8e2d34f8f])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:928be855afc6d08aa10851973ffc4577b1b71c2a2927a41beacd6db8e2d34f8f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:928be855afc6d08aa10851973ffc4577b1b71c2a2927a41beacd6db8e2d34f8f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 3s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1379

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1379/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309022049",
            "environmentId": "HjyBkSMZBUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310"
      }
    ]
  },
  "name": "go-testxlang_partition-601",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/09 03:18:21 Submitted job: 2023-03-08_19_18_20-9652032965171828145
2023/03/09 03:18:21 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-08_19_18_20-9652032965171828145?project=apache-beam-testing
2023/03/09 03:18:21 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-08_19_18_20-9652032965171828145
2023/03/09 03:18:21 Job state: JOB_STATE_PENDING ...
2023/03/09 03:18:51 Job still running ...
2023/03/09 03:19:21 Job still running ...
2023/03/09 03:19:51 Job still running ...
2023/03/09 03:20:21 Job still running ...
2023/03/09 03:20:51 Job still running ...
2023/03/09 03:21:21 Job still running ...
2023/03/09 03:21:51 Job still running ...
2023/03/09 03:22:22 Job still running ...
2023/03/09 03:22:52 Job still running ...
2023/03/09 03:23:22 Job still running ...
2023/03/09 03:23:52 Job still running ...
2023/03/09 03:24:22 Job still running ...
2023/03/09 03:24:52 Job still running ...
2023/03/09 03:25:22 Job still running ...
2023/03/09 03:25:52 Job still running ...
2023/03/09 03:26:22 Job still running ...
2023/03/09 03:26:52 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-08_19_18_20-9652032965171828145 failed
--- FAIL: TestXLang_Partition (550.89s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3218.848s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678329226785108006
--- FAIL: TestBigQueryIO_BasicWriteRead (4.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42881 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wEvOFxjYws"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wEvOFxjYws"}}  windowing_strategies:{key:"w0@wEvOFxjYws"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wEvOFxjYws"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wEvOFxjYws"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wEvOFxjYws"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678329226785108006\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wEvOFxjYws"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42881 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wEvOFxjYws"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wEvOFxjYws"}}  windowing_strategies:{key:"w0@wEvOFxjYws"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wEvOFxjYws"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wEvOFxjYws"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wEvOFxjYws"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678329226785108006\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wEvOFxjYws"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc000345c40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc000345c40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a77a0?, 0xc0000bd9f0?}, {0x11384d6, 0x39}, {0xc0000f00c0?, 0xa9cba0?, 0x1?}, {0xc000043d90, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7740?, 0xc0000bd9f0?}, {0xc00060e3c0, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0x7ff1e57d0508?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043d90, 0xf}, {0xc00060e3c0, 0x52}, {0xeba6e0, 0xc00017b0b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000462b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000462b60, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.496s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9dedfd8efd74e9a2049310ef4037e17b4d150a9371246dad22b7f73d8c8e3cb
Deleted: sha256:26507ae8846f2999644f426413d7fac763a582e79a227dab379ab5a40f227d44
Deleted: sha256:dc07585489df5d38d3bdff7ccde853413ea4ddb37442c8eeaaf0e178b64b362b
Deleted: sha256:413598f452f9d8a9f6a9f277387bf5ca5adc343283da58d6ae75b2bbdea868ac
Deleted: sha256:8a7f64d188602192e904276e6265696f5f1729b96d3a53ff9c3e25c8149fa411
Deleted: sha256:16d029e8d0d4cc8e790e19f3841302183f16b101b58680b13b6ae04f2e886c9d
Deleted: sha256:fdf0b52b5ba6935b8a3a8bd19ca8884576a872b48947676851860d71fff564a6
Deleted: sha256:a898f2e0fcf6e6f66fa3446ac985936734e7a40617599b004eda9ba921e5d765
Deleted: sha256:6b82db0f90d135b1f73104f98238955619f6dcade2fea926f2e8f461ccfa49ec
Deleted: sha256:e8e6490543b5b675f8d0a93f9f69976c5af20a45ba519bb56fa38741cf27f51e
Deleted: sha256:4f86494f6d7d647b1e73099c3386f3478c1c55dc53a4471cf177f4d8fcfce578
Deleted: sha256:4cbd3c1e0cc7897ec84ef0a860dd3c235b967d78def59b5a8995c4697fd666ca
Deleted: sha256:66f07ce1424448989e215cf7f9e46b6d2c83f4d1c62f753ae3468e6e969fd10b
Deleted: sha256:1fcd03d8cb2d534078f4792b89de777845d8988062898922ecfaa6126dca1e35
Deleted: sha256:6777426a54b3ce1f6522750bb3cfa889f9219e2533cdeba0e1ee22a20b8b4c1c
Deleted: sha256:5c0ad9b66fa37ac1e7cbd4b73eb31f3a9081bfcc4ec1a8eb2bb306eb4e766e22
Deleted: sha256:8b08b3df150797081330c4fd12b76ed9092ec8188f566cf28fe0054123b6659c
Deleted: sha256:383e9c65aa469df2c9009b87f9f96149b101219071af5720181e1cc4aad3bc3d
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9dedfd8efd74e9a2049310ef4037e17b4d150a9371246dad22b7f73d8c8e3cb
  Associated tags:
 - 20230309-023310
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230309-023310].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9dedfd8efd74e9a2049310ef4037e17b4d150a9371246dad22b7f73d8c8e3cb].
$ rm -rf /tmp/tmp.KXGI3kVN69
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309022049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230309022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9ddd4349ac03f42c18ed40fe1c34e07addccdf9f6d902510b5da6c252f14e3c9].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309022049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230309022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fc9e5242f2ad4a218b911a022b9d412da0e31ac65d0ccccdedf968e7c732a55d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3495469.
Stopping expansion service pid: 3495470.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 4s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1378

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1378/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308202045",
            "environmentId": "zNPQKcqOofbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327"
      }
    ]
  },
  "name": "go-testxlang_partition-619",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/08 21:18:45 Submitted job: 2023-03-08_13_18_45-1888129886308759941
2023/03/08 21:18:45 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-08_13_18_45-1888129886308759941?project=apache-beam-testing
2023/03/08 21:18:45 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-08_13_18_45-1888129886308759941
2023/03/08 21:18:45 Job state: JOB_STATE_PENDING ...
2023/03/08 21:19:15 Job still running ...
2023/03/08 21:19:45 Job still running ...
2023/03/08 21:20:15 Job still running ...
2023/03/08 21:20:45 Job still running ...
2023/03/08 21:21:15 Job still running ...
2023/03/08 21:21:45 Job still running ...
2023/03/08 21:22:15 Job still running ...
2023/03/08 21:22:45 Job still running ...
2023/03/08 21:23:15 Job still running ...
2023/03/08 21:23:46 Job still running ...
2023/03/08 21:24:16 Job still running ...
2023/03/08 21:24:46 Job still running ...
2023/03/08 21:25:16 Job still running ...
2023/03/08 21:25:46 Job still running ...
2023/03/08 21:26:16 Job still running ...
2023/03/08 21:26:46 Job still running ...
2023/03/08 21:27:16 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-08_13_18_45-1888129886308759941 failed
--- FAIL: TestXLang_Partition (551.14s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3224.186s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678307646952893012
--- FAIL: TestBigQueryIO_BasicWriteRead (6.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34157 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@GTKJFNQQzs"  is_bounded:BOUNDED  windowing_strategy_id:"w0@GTKJFNQQzs"}}  windowing_strategies:{key:"w0@GTKJFNQQzs"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@GTKJFNQQzs"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@GTKJFNQQzs"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@GTKJFNQQzs"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678307646952893012\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"GTKJFNQQzs"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34157 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@GTKJFNQQzs"  is_bounded:BOUNDED  windowing_strategy_id:"w0@GTKJFNQQzs"}}  windowing_strategies:{key:"w0@GTKJFNQQzs"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@GTKJFNQQzs"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@GTKJFNQQzs"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@GTKJFNQQzs"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678307646952893012\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"GTKJFNQQzs"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 15 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc0005b0780})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc0005b0780})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048e760?, 0xc0005ac370?}, {0x11384d6, 0x39}, {0xc000258000?, 0xa9cba0?, 0x1?}, {0xc000127240, 0xf}, 0xc000177d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048e700?, 0xc0005ac370?}, {0xc0005bc720, 0x52}, {0x1?}, {0xc000177ea8, 0x2, 0xe793e0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000127240, 0xf}, {0xc0005bc720, 0x52}, {0xeba6e0, 0xc0005aea08})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.246s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.050s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:56472c3dbf1b31013ac49ada949fbf464776b41696226778d8335ff82a54b583
Deleted: sha256:bf0bf8bd0906f3c2562a8197f3a8736518fda8e7b3377812fc84914507900bcf
Deleted: sha256:422ef855a0a8dace610ab3d79b13260a9de19b47c1f41b9c6813f4d329c48016
Deleted: sha256:8a13095757717739db96fe4dbd2c0968056a0bf62abd19d8237fc4b60f26544c
Deleted: sha256:f656a522fe33855213be06c37579c2990299d4eb1eb2bdd05b4fd690ff6e3b10
Deleted: sha256:ba37ba701a637e3e0cd6e6a63bd7ae6ee6488d09fa825716dc7b2b41cde2d8e9
Deleted: sha256:958b654edbc4776efb41612e042af0d7a0295a5ae926ee3e078aedebb0b71cd1
Deleted: sha256:703ac19d4f70c19322864079bfc517b99a65eda592d8c6f1dc7f1fdebcf83419
Deleted: sha256:5000d42a9aa59ea82db78daa72e94e47c5701edf66ecb14185647aa02226ec3a
Deleted: sha256:4563ed05e630bf72d485a3e118ff004d5647a81a8518d14dafa590e210f766ee
Deleted: sha256:6e11d06847050ee3b2f2ea8639db64d6a1b75ed0a59dfeee58f6bd6f2faef190
Deleted: sha256:dc51a749f0af5071362323b2c1700198f4d672f12a032e0008d7fcf54bf86c61
Deleted: sha256:0c5bdd3e747093bf4b485747d46c00ae95fa52c0c9d32498d34899b683727b54
Deleted: sha256:ee67d6091649062ea6773b1048af440f10420d8c9a120dd2c601cf413801341e
Deleted: sha256:cd4f72a778c1d75caa250ccc8e7469806f6fb7490b87ac53ae4d7267c2f2e044
Deleted: sha256:d932677e567a9e7d1237197942b8c4e0bf254f5e9598ad8ed4c579361466e410
Deleted: sha256:6448e8abf57282ab5612e63d06fff383dcef207292edc8ea5f3a3f64e2a10bce
Deleted: sha256:5bd0e5c4628011e7b90af16ca063f4d6db3c1549d198cc84a5b1be3ab50bccac
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:56472c3dbf1b31013ac49ada949fbf464776b41696226778d8335ff82a54b583
  Associated tags:
 - 20230308-203327
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-203327].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:56472c3dbf1b31013ac49ada949fbf464776b41696226778d8335ff82a54b583].
$ rm -rf /tmp/tmp.QZN4p2BCck
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:92e7fc9dbd6d6d9dc0206e39fe894d9d834a1e6ffb02cf416d37111d5b138ecc].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:eabddb02bee22e09d34899b6064870e32dfd1f6ca8066c6aa43bb02f045f044e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3018212.
Stopping expansion service pid: 3018213.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 29s
232 actionable tasks: 161 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1377

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1377/display/redirect?page=changes>

Changes:

[noreply] [Spark Dataset runner] Remove obsolete code (#25734)


------------------------------------------
[...truncated 1.02 MB...]
2023/03/08 15:24:35 Job still running ...
2023/03/08 15:25:05 Job still running ...
2023/03/08 15:25:35 Job still running ...
2023/03/08 15:26:05 Job still running ...
2023/03/08 15:26:35 Job still running ...
2023/03/08 15:27:05 Job still running ...
2023/03/08 15:27:35 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-08_07_19_04-3186546073453742027 failed
--- FAIL: TestXLang_Partition (558.64s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3324.794s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678285964351833041
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38543 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SfFtLONjWb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SfFtLONjWb"}}  windowing_strategies:{key:"w0@SfFtLONjWb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SfFtLONjWb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SfFtLONjWb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SfFtLONjWb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678285964351833041\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SfFtLONjWb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38543 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SfFtLONjWb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SfFtLONjWb"}}  windowing_strategies:{key:"w0@SfFtLONjWb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SfFtLONjWb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SfFtLONjWb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SfFtLONjWb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678285964351833041\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SfFtLONjWb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc000236400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc000236400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010ee20?, 0xc00061b630?}, {0x11384d6, 0x39}, {0xc0004ea0c0?, 0xa9cba0?, 0x1?}, {0xc00048ed50, 0xf}, 0xc000663d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010edc0?, 0xc00061b630?}, {0xc0004e8480, 0x52}, {0x1?}, {0xc000663ea8, 0x2, 0x7fd3817fe438?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ed50, 0xf}, {0xc0004e8480, 0x52}, {0xeba6e0, 0xc000674060})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.479s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-143208
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-143208
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4688b501bdded176c1fd6799660f5e72532554f10a69192141ebabaa273ef282
Deleted: sha256:6c159963081577ce07fa2a30b6df9b9c5cd78441067af363f16b5e9abe249b9a
Deleted: sha256:74e4ac5fb4276e07a868e2b185c76bd3a95860976d6adc290ea570fce77af4c8
Deleted: sha256:bcef574291a521c164aa3963166b9366a46943d9c6361a980d81b530be4dbf50
Deleted: sha256:4553b2b4de852b83edcb9fbc98147589b9a433ff375a5cdde2a4885fc4d10823
Deleted: sha256:8beddcd6dae14adeed1c0a8dbe337b397deb8f7220323d184b108f38b73237b6
Deleted: sha256:3f54d38642bca843ef3cc29865d46f7ee106a0e90a333f9d84504b761ec652ca
Deleted: sha256:fd9417b9177810856df186f7c719fa56b6e800eb6cf471f5c24bfbd86697cf16
Deleted: sha256:f379d2489bff5ea144ecc0e2d9d211ded1fd6ef456dddfac5e2df5977e54ee6d
Deleted: sha256:aafb3a40d6a82c389964d0be916b783c4e0318673d369e29a951ffb142abc437
Deleted: sha256:2f672caca8b516148af87fa932332a4f0623f631019b2a13be1a30ed20827b40
Deleted: sha256:0b57fb2acee0637cb900439b0da81283b3f901e5907f0d36da07c5598fa11f7c
Deleted: sha256:606d77baac648c042277ebec5a7214ff794c429832309924aca2bf47f17549cb
Deleted: sha256:fa391b6796c0b5d009eec3528cf6f00c9af70e3c87479132a42e57ab5866cb9d
Deleted: sha256:3d420b7fd54b5f3c433e97dc62185853e7cb6e6fcefde107018d86c26859f58b
Deleted: sha256:1ab52cdddd1da6c1e11dff6d46c17ef67200273b96d7ced65ac2d341ce1790be
Deleted: sha256:716d87c3a30e7c8eade33562113b8c5b58e95ceca67c81ddf7054fb9192d4fb2
Deleted: sha256:ebd322378b8889f8ecd34a39f4f85245e4df81695e8f784590d6ec1f669a7f74
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-143208
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4688b501bdded176c1fd6799660f5e72532554f10a69192141ebabaa273ef282
  Associated tags:
 - 20230308-143208
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-143208
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-143208].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4688b501bdded176c1fd6799660f5e72532554f10a69192141ebabaa273ef282].
$ rm -rf /tmp/tmp.6HFyX6Xejv
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308142043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38d7852b957abfecfcaccc316149b39286565f2e37adb475d6a25de902299019].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308142043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e
Deleted: sha256:bafb71edeac0707d3c9f2a510466d7798b5be27a4f481dc0b2186580f16a0fa1
Deleted: sha256:666183c44aeb784918acb18f2efe17f83b73f748ee7a311b1ed60a88b6f82fc9
Deleted: sha256:cdec1c9b2d5e5451129d68b8af85fa722e7e7482b3ee7bf2c4347ebf315b9e53
Deleted: sha256:e05de4df556b1a861982454983d9746577e3c571ddf3cd0f5e4abeb75cf086ab
Deleted: sha256:2d75bab82ba21d7d6859b08e5f0162b529bf62fe36b32765625b7b661928ec8b
Deleted: sha256:2142a13e4149ff99c227cc78b00ffd3db18bbc942378fc4d9705464feab5afd9
Deleted: sha256:9b3211fb4ad429982f15154a1fc19577c5883174c9ed8be890cba2414fde8694
Deleted: sha256:cd074e9ce4f63b355676f2c91bcf9c9f55f9022b4a8c5ac04ced57826822f4da
Deleted: sha256:fafc461838b688fb517fb3088ea71ebc9e2ef79fa74f483be2b4d119fa039e61
Deleted: sha256:853c541b22e539ca6c959c2f58237f1a49b7c6d73b7df5b82d3703f83ea030b2
Deleted: sha256:1883801a5ab544673efe1658be6bae23e3543a64eba0a3543d203270f2f50ad3
Deleted: sha256:c0b26cb031c8b783f4a35a3d8a7558dc5277109ddea6950a23f8aed7f25de38f
Deleted: sha256:f7d225c93a9eaf887102f1e8e924e7eda2b9aa39d9d6208ef81e05e6a1e2fccb
Deleted: sha256:6f340c3b2ccd497bf1830ef5384848ae9976e5c89784ce7cc5fffbf551f3788e
Deleted: sha256:2cdbcb46232a72fc783bb116e0336c4b90a78d3247b96d78685296480feb537a
Deleted: sha256:13995cfd84ec38699e7215efa5d7fd28b181526bbe28d5528954f7322938d99b
Deleted: sha256:a226b3691468d72f467b81fa32593f715a49cf200de0edbe082ae4cfa83b06e4
Deleted: sha256:36b5f686374df91c2992c10feeb9a2d2fa35ead2354a39440dcbb7bc9a3b82e2
Deleted: sha256:9ed04579265f7fea9a6825a55f506a8736606a2cf7e11a591ce31948acbb2485
Deleted: sha256:9e447bd127cfb9afd0b8d183a97eb31854fad914392cde190fb95f0324c99c74
Deleted: sha256:9e79724b7e3daf57f1011f4ee751ef0f91e2c73fed934d3f18bb8477a893f56a
Deleted: sha256:e74758adadd84cf70f869bc3ffe268796577c5c8a439135f1be0b06a88f30a29
Deleted: sha256:735dababe3b34dfcbf46ba255c62c023f7b4236a7ba1910c69c758d5753afe48
Deleted: sha256:031c921bbb17310e2becf1766e2e653a50336723324312483d08215d90b8d985
Deleted: sha256:998fa0d72078a9a4ba9326165680fc44bcbd656e9d27308ceda7944c1ecdc170
Deleted: sha256:dccbe75711bc657c2f69b656424206135251e037094fb34742c41fd769a25f1a
Deleted: sha256:9a0c248edf9791f9d34b071d476b89f91fcfc991bec4486141996ddd60ab3100
Deleted: sha256:b1df1802706e196143d164b6d9e0ddd0feeeb298fafa5bec4da2006dffe00da2
Deleted: sha256:e29cec350ca5324a72dccfec212a332a0c8dd7d7fdf7a76cf32777f1040c0751
Deleted: sha256:a792db9e1b9c77435fcae9ef420b2e8a07a597424827629e17743130a29a557e
Deleted: sha256:74ca1175aa22b935f594456f1d70b515fdfca3dd4d0d96da61e58cbaee0aa4b0
Deleted: sha256:50c1261f04c5ff661615d36d4b878a42311f79ec427c7f25a1fe47d815bd786d
Deleted: sha256:f32e836eb1fe0f983c76196a0ac3f85fec17ee410f05aad0b87c202f08dea468
Deleted: sha256:7504066ee813db477b79c59a84979a00185efa07db34710299e7418987fea5fe
Deleted: sha256:3e3587f84d5a751b784cc06035ced42d6b5b78b4fb4f4fb2310b7e7c3803537d
Deleted: sha256:9e9e86a052e621d29ad92572f04f84b471a10c84faba701fb0b1aa5339af0ae0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b90600f83ac8a437fee2ffdbfcf867e785456b687bc3ec28f686fee2aa18879e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2233910.
Stopping expansion service pid: 2233911.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 10s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1376

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1376/display/redirect>

Changes:


------------------------------------------
[...truncated 589.52 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308082036",
            "environmentId": "BYulSIMPjdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246"
      }
    ]
  },
  "name": "go-testxlang_partition-237",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/08 09:19:15 Submitted job: 2023-03-08_01_19_15-112360316340449480
2023/03/08 09:19:15 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-08_01_19_15-112360316340449480?project=apache-beam-testing
2023/03/08 09:19:15 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-08_01_19_15-112360316340449480
2023/03/08 09:19:16 Job state: JOB_STATE_PENDING ...
2023/03/08 09:19:46 Job still running ...
2023/03/08 09:20:16 Job still running ...
2023/03/08 09:20:46 Job still running ...
2023/03/08 09:21:16 Job still running ...
2023/03/08 09:21:46 Job still running ...
2023/03/08 09:22:16 Job still running ...
2023/03/08 09:22:46 Job still running ...
2023/03/08 09:23:16 Job still running ...
2023/03/08 09:23:46 Job still running ...
2023/03/08 09:24:16 Job still running ...
2023/03/08 09:24:46 Job still running ...
2023/03/08 09:25:16 Job still running ...
2023/03/08 09:25:46 Job still running ...
2023/03/08 09:26:16 Job still running ...
2023/03/08 09:26:46 Job still running ...
2023/03/08 09:27:16 Job still running ...
2023/03/08 09:27:46 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-08_01_19_15-112360316340449480 failed
--- FAIL: TestXLang_Partition (550.59s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3298.663s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678264401447695998
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43109 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@nTLrEdvdOK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@nTLrEdvdOK"}}  windowing_strategies:{key:"w0@nTLrEdvdOK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@nTLrEdvdOK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@nTLrEdvdOK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@nTLrEdvdOK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678264401447695998\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"nTLrEdvdOK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43109 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@nTLrEdvdOK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@nTLrEdvdOK"}}  windowing_strategies:{key:"w0@nTLrEdvdOK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@nTLrEdvdOK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@nTLrEdvdOK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@nTLrEdvdOK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678264401447695998\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"nTLrEdvdOK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc0005ac780})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc0005ac780})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169860?, 0xc0001399f0?}, {0x11384d6, 0x39}, {0xc000200000?, 0xa9cba0?, 0x1?}, {0xc00048acb0, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169800?, 0xc0001399f0?}, {0xc000652300, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f17382137f0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048acb0, 0xf}, {0xc000652300, 0x52}, {0xeba6e0, 0xc00048bfc0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cc820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cc820, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.426s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1081b61661ef2c5321d08edd74d1289199f330174903f2f25b9254acd72791eb
Deleted: sha256:4d0d20030f143958d718f89ea4f8a73ef0a2f26e0dbd73dfed4e142e232a697e
Deleted: sha256:40a4fd0c55c8d0d6da728048968425459c2a2279838b9f99dc6d19b00f00a3e1
Deleted: sha256:f562d9d48e461e003568f579b37b7b59ed552d17d5772c46e15ca15d7f0758ab
Deleted: sha256:365b0ec1929f1a87d7f96d90c9216c53027b01257670551f7f0be68da508a64e
Deleted: sha256:c85ace2eeb7db14bd389f0a85500c6990b778096c3e897479672244c2f2a8dab
Deleted: sha256:710dc75aabf71223857ae2dd6124e432fa1c02cbec6c17a9b5caaa4850a22353
Deleted: sha256:d1e44975c2235eff3a5d55d3a95ffacf5ac96883b295fda7a73fd5c912f3d89c
Deleted: sha256:d7ee6613b97ef162320c43132a17bc34d7b06dc13a05fc229878a812133fb0bf
Deleted: sha256:3c7c352ba867b9eef985db4475f687e018ea3743fb12c95ee38efdfe83a280c8
Deleted: sha256:f21438e7ff92552f30705ea14ada3eff4cfaafec282b1a235b7366b55758df0c
Deleted: sha256:a29ac58916276c3afd7f365b267842bb215e89d878cf3fc63eef55f67eccf744
Deleted: sha256:8188142aef3457f3fd97efd6c84252d1f47f9d9655e0764d61d5687ea24de2ee
Deleted: sha256:609b8d3c0fd16aa7f04fc82c21ecd42c3a678c1ef635eeef2cf3ff79e3e1f474
Deleted: sha256:f9e516d0448761b4044583da441d3b343a057e10dc2471d0b13d59722977128f
Deleted: sha256:8a3a4b3c9222c35b83da16d94aafb8ec1bf031d8871a89f09a7cd58e5c9fa249
Deleted: sha256:d1a89c0e8b560531e3b8dc216f97156cd5b22c0a9623b6fa6b78a64da7bd1485
Deleted: sha256:276c933f15572177b70ed2bf79321452461960fac95c8e9b11a89ba79bf6cfae
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1081b61661ef2c5321d08edd74d1289199f330174903f2f25b9254acd72791eb
  Associated tags:
 - 20230308-083246
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-083246].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1081b61661ef2c5321d08edd74d1289199f330174903f2f25b9254acd72791eb].
$ rm -rf /tmp/tmp.EINCvDi8D5
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308082036
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308082036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308082036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5d057aeceaec4d311fd7e44fba4de88a00df56c74f1ae84a9742c12284281cf].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308082036
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308082036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308082036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d414d7642a9c77519e029863ce5c49048d0abe235bf26c589423164774fc702b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2127010.
Stopping expansion service pid: 2127011.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 10s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1375

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1375/display/redirect>

Changes:


------------------------------------------
[...truncated 1018.70 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-023155",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308022040",
            "environmentId": "hvMGpSZsPAbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-023155"
      }
    ]
  },
  "name": "go-testxlang_partition-140",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/08 03:17:31 Submitted job: 2023-03-07_19_17_31-3416346322283794632
2023/03/08 03:17:31 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-07_19_17_31-3416346322283794632?project=apache-beam-testing
2023/03/08 03:17:31 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-07_19_17_31-3416346322283794632
2023/03/08 03:17:31 Job state: JOB_STATE_PENDING ...
2023/03/08 03:18:01 Job still running ...
2023/03/08 03:18:31 Job still running ...
2023/03/08 03:19:01 Job still running ...
2023/03/08 03:19:31 Job still running ...
2023/03/08 03:20:01 Job still running ...
2023/03/08 03:20:31 Job still running ...
2023/03/08 03:21:01 Job still running ...
2023/03/08 03:21:31 Job still running ...
2023/03/08 03:22:01 Job still running ...
2023/03/08 03:22:32 Job still running ...
2023/03/08 03:23:02 Job still running ...
2023/03/08 03:23:32 Job still running ...
2023/03/08 03:24:02 Job still running ...
2023/03/08 03:24:32 Job still running ...
2023/03/08 03:25:02 Job still running ...
2023/03/08 03:25:32 Job still running ...
2023/03/08 03:26:02 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-07_19_17_31-3416346322283794632 failed
--- FAIL: TestXLang_Partition (551.21s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3242.389s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678242753168775800
--- FAIL: TestBigQueryIO_BasicWriteRead (4.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40279 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@DBhRZKebjN"  is_bounded:BOUNDED  windowing_strategy_id:"w0@DBhRZKebjN"}}  windowing_strategies:{key:"w0@DBhRZKebjN"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@DBhRZKebjN"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@DBhRZKebjN"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@DBhRZKebjN"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678242753168775800\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"DBhRZKebjN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40279 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@DBhRZKebjN"  is_bounded:BOUNDED  windowing_strategy_id:"w0@DBhRZKebjN"}}  windowing_strategies:{key:"w0@DBhRZKebjN"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@DBhRZKebjN"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@DBhRZKebjN"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@DBhRZKebjN"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678242753168775800\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"DBhRZKebjN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 30 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc0002dc740})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc0002dc740})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169b60?, 0xc000139a90?}, {0x11384d6, 0x39}, {0xc000202000?, 0xa9cba0?, 0x1?}, {0xc000552ca0, 0xf}, 0xc000031d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169aa0?, 0xc000139a90?}, {0xc00055e360, 0x52}, {0x1?}, {0xc000031ea8, 0x2, 0x7f5e368d3728?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000552ca0, 0xf}, {0xc00055e360, 0x52}, {0xeba6e0, 0xc000553fb0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000550680)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000550680, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.499s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f67e97866b89ba368f73f9a694ae2f7c4e720998841c998a08a785b3519bb7ce
  Associated tags:
 - 20230308-023155
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-023155
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230308-023155].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f67e97866b89ba368f73f9a694ae2f7c4e720998841c998a08a785b3519bb7ce].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:649cc1eda23c08e0d894f07018f7f7c703f1bb071fb1a9b51ba332382ba25523]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230308022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:649cc1eda23c08e0d894f07018f7f7c703f1bb071fb1a9b51ba332382ba25523])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:649cc1eda23c08e0d894f07018f7f7c703f1bb071fb1a9b51ba332382ba25523
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:649cc1eda23c08e0d894f07018f7f7c703f1bb071fb1a9b51ba332382ba25523].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f9a5d19e5b11c009674296a657baa33126c94c6d777c4d19f615660e1533687]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230308022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f9a5d19e5b11c009674296a657baa33126c94c6d777c4d19f615660e1533687])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f9a5d19e5b11c009674296a657baa33126c94c6d777c4d19f615660e1533687
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f9a5d19e5b11c009674296a657baa33126c94c6d777c4d19f615660e1533687].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 17s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1374

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1374/display/redirect>

Changes:


------------------------------------------
[...truncated 1.04 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307202044",
            "environmentId": "uiNaIhqMdNbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239"
      }
    ]
  },
  "name": "go-testxlang_partition-978",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/07 21:18:22 Submitted job: 2023-03-07_13_18_21-419513544407597804
2023/03/07 21:18:22 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-07_13_18_21-419513544407597804?project=apache-beam-testing
2023/03/07 21:18:22 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-07_13_18_21-419513544407597804
2023/03/07 21:18:22 Job state: JOB_STATE_PENDING ...
2023/03/07 21:18:52 Job still running ...
2023/03/07 21:19:22 Job still running ...
2023/03/07 21:19:52 Job still running ...
2023/03/07 21:20:22 Job still running ...
2023/03/07 21:20:52 Job still running ...
2023/03/07 21:21:22 Job still running ...
2023/03/07 21:21:52 Job still running ...
2023/03/07 21:22:22 Job still running ...
2023/03/07 21:22:52 Job still running ...
2023/03/07 21:23:22 Job still running ...
2023/03/07 21:23:52 Job still running ...
2023/03/07 21:24:22 Job still running ...
2023/03/07 21:24:52 Job still running ...
2023/03/07 21:25:23 Job still running ...
2023/03/07 21:25:53 Job still running ...
2023/03/07 21:26:23 Job still running ...
2023/03/07 21:26:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-07_13_18_21-419513544407597804 failed
--- FAIL: TestXLang_Partition (551.93s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3245.418s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678221206347718448
--- FAIL: TestBigQueryIO_BasicWriteRead (4.23s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42927 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@KlJKNHFfWS"  is_bounded:BOUNDED  windowing_strategy_id:"w0@KlJKNHFfWS"}}  windowing_strategies:{key:"w0@KlJKNHFfWS"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@KlJKNHFfWS"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@KlJKNHFfWS"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@KlJKNHFfWS"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678221206347718448\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"KlJKNHFfWS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42927 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@KlJKNHFfWS"  is_bounded:BOUNDED  windowing_strategy_id:"w0@KlJKNHFfWS"}}  windowing_strategies:{key:"w0@KlJKNHFfWS"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@KlJKNHFfWS"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@KlJKNHFfWS"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@KlJKNHFfWS"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678221206347718448\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"KlJKNHFfWS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 52 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc00048d040})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc00048d040})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005a6e60?, 0xc0004996d0?}, {0x11384d6, 0x39}, {0xc00025c0c0?, 0xa9cba0?, 0x1?}, {0xc000043d80, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005a6e00?, 0xc0004996d0?}, {0xc00059a5a0, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7f1415cd54e0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043d80, 0xf}, {0xc00059a5a0, 0x52}, {0xeba6e0, 0xc0001a70a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001031e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001031e0, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.269s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4015645e2f79ab9731b144a53f0d28f7fee82ebe5599a23eb35b0645ef55e480
Deleted: sha256:52f25c7222f703beaee8c17c04367a26b81e91fdbbf2a9899cd611aaf3266e66
Deleted: sha256:ba1a1dd72edf0414109b46b02c8609d429ae4bed8542fc7215082a2d110b8ea4
Deleted: sha256:54b675a38d608e4386c1a778fc4bf721e0802527fea46420bf17b744ba98d966
Deleted: sha256:966c231308d56b0fc150a00e6eea22112f55667284869537ccc221b1f6caee45
Deleted: sha256:cc19f187a9b0038d741c4b563f3d09ae774162fe23457fcbed02618fd1efc167
Deleted: sha256:e3be15886695f8429172f1b196273a8b616a3cfa6283ff505ef036701af4d227
Deleted: sha256:7f858b538dcefae4ddc4541c36acd04c5f29488123fffc6d6a96e04173b3945e
Deleted: sha256:3cfca684106d5df7e5a65aec425c8e04195596e74edc2cad34f261be14a44a49
Deleted: sha256:3599604c04adb6cb65dc4dc1364d68169f8556c05a12d9a49a98fe6d927062e0
Deleted: sha256:82ab59130aad93ac7a8df173c5a2f84b0098221b60713328fabbf22e649e653d
Deleted: sha256:683677e70c3949e0f490d4696b52315bdabeadde5a4145fd899e02b3173af645
Deleted: sha256:b2193ca9e577f575c2df656f7b804a8172b2656bb498300e9fe102394c84ecb7
Deleted: sha256:d0d627f133008186e262d40aa10b3736d54609e6e4b2fb012fd9341a57e12568
Deleted: sha256:4c20a953c1c560d674256f67304885026749e3a9071155b9706e4f17d061fb3b
Deleted: sha256:3fe5a6a7f511ea84f432ab639bf085c23775960f247f50cd07344d5e468a359b
Deleted: sha256:96a24ee690eae000a0b73edf8eb8e843e11fe5d6dd1b3018748b2b044b89536c
Deleted: sha256:a95b3555ce083c7dccfa61eeaf5b646ed00883c0c818c8694ed392cf21f6ca45
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4015645e2f79ab9731b144a53f0d28f7fee82ebe5599a23eb35b0645ef55e480
  Associated tags:
 - 20230307-203239
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-203239].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4015645e2f79ab9731b144a53f0d28f7fee82ebe5599a23eb35b0645ef55e480].
$ rm -rf /tmp/tmp.Yt9bA13b6s
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307202044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b71d24b4dcd47719c9ddc9ea15e9728e6fb1b67f397d80811834156985b4443].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307202044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:48b704ab393ba01390eac349d6fd0f68c1961f399932bd005501bf09cecce48b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1741938.
Stopping expansion service pid: 1741939.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 8s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1373

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1373/display/redirect>

Changes:


------------------------------------------
[...truncated 1022.38 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-143210",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307142041",
            "environmentId": "GEWqszyracbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-143210"
      }
    ]
  },
  "name": "go-testxlang_partition-191",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/07 15:15:52 Submitted job: 2023-03-07_07_15_52-3160653701080719021
2023/03/07 15:15:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-07_07_15_52-3160653701080719021?project=apache-beam-testing
2023/03/07 15:15:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-07_07_15_52-3160653701080719021
2023/03/07 15:15:52 Job state: JOB_STATE_PENDING ...
2023/03/07 15:16:22 Job still running ...
2023/03/07 15:16:52 Job still running ...
2023/03/07 15:17:22 Job still running ...
2023/03/07 15:17:52 Job still running ...
2023/03/07 15:18:22 Job still running ...
2023/03/07 15:18:52 Job still running ...
2023/03/07 15:19:22 Job still running ...
2023/03/07 15:19:52 Job still running ...
2023/03/07 15:20:22 Job still running ...
2023/03/07 15:20:52 Job still running ...
2023/03/07 15:21:22 Job still running ...
2023/03/07 15:21:53 Job still running ...
2023/03/07 15:22:23 Job still running ...
2023/03/07 15:22:53 Job still running ...
2023/03/07 15:23:23 Job still running ...
2023/03/07 15:23:53 Job still running ...
2023/03/07 15:24:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-07_07_15_52-3160653701080719021 failed
--- FAIL: TestXLang_Partition (551.49s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3128.565s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678199568076286743
--- FAIL: TestBigQueryIO_BasicWriteRead (4.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40081 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BIkabgjwZa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BIkabgjwZa"}}  windowing_strategies:{key:"w0@BIkabgjwZa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BIkabgjwZa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BIkabgjwZa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BIkabgjwZa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678199568076286743\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BIkabgjwZa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40081 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BIkabgjwZa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BIkabgjwZa"}}  windowing_strategies:{key:"w0@BIkabgjwZa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BIkabgjwZa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BIkabgjwZa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BIkabgjwZa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678199568076286743\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BIkabgjwZa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc000462e00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc000462e00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048ac20?, 0xc00001f630?}, {0x11384d6, 0x39}, {0xc0000f00c0?, 0xa9cba0?, 0x1?}, {0xc000482c60, 0xf}, 0xc00012fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048abc0?, 0xc00001f630?}, {0xc00001c300, 0x52}, {0x1?}, {0xc00012fea8, 0x2, 0x7f4a2b4dc2a0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000482c60, 0xf}, {0xc00001c300, 0x52}, {0xeba6e0, 0xc000483f70})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00049aea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00049aea0, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.492s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2365cae518ad2ad65d4359be6d00688fae811697c8ff91b98d48988b7c664c1b
  Associated tags:
 - 20230307-143210
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-143210
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-143210].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2365cae518ad2ad65d4359be6d00688fae811697c8ff91b98d48988b7c664c1b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:db894265c1c74d91932dbbd5bd16617624251cbba9fd28b68f814cc5a25a5414]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:db894265c1c74d91932dbbd5bd16617624251cbba9fd28b68f814cc5a25a5414])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:db894265c1c74d91932dbbd5bd16617624251cbba9fd28b68f814cc5a25a5414
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:db894265c1c74d91932dbbd5bd16617624251cbba9fd28b68f814cc5a25a5414].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307142041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:276709e8f3a22880ee197ea9ac412ffec8695ded5d1d99d8b7644cdea3927da2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307142041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:276709e8f3a22880ee197ea9ac412ffec8695ded5d1d99d8b7644cdea3927da2])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:276709e8f3a22880ee197ea9ac412ffec8695ded5d1d99d8b7644cdea3927da2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:276709e8f3a22880ee197ea9ac412ffec8695ded5d1d99d8b7644cdea3927da2].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 39s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1372

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1372/display/redirect>

Changes:


------------------------------------------
[...truncated 567.63 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-083231",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307082035",
            "environmentId": "rnMkAgklbibeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-083231"
      }
    ]
  },
  "name": "go-testxlang_partition-389",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/07 09:18:10 Submitted job: 2023-03-07_01_18_10-14330950567437301559
2023/03/07 09:18:10 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-07_01_18_10-14330950567437301559?project=apache-beam-testing
2023/03/07 09:18:10 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-07_01_18_10-14330950567437301559
2023/03/07 09:18:11 Job state: JOB_STATE_PENDING ...
2023/03/07 09:18:41 Job still running ...
2023/03/07 09:19:11 Job still running ...
2023/03/07 09:19:41 Job still running ...
2023/03/07 09:20:11 Job still running ...
2023/03/07 09:20:41 Job still running ...
2023/03/07 09:21:11 Job still running ...
2023/03/07 09:21:41 Job still running ...
2023/03/07 09:22:11 Job still running ...
2023/03/07 09:22:41 Job still running ...
2023/03/07 09:23:11 Job still running ...
2023/03/07 09:23:41 Job still running ...
2023/03/07 09:24:11 Job still running ...
2023/03/07 09:24:41 Job still running ...
2023/03/07 09:25:11 Job still running ...
2023/03/07 09:25:42 Job still running ...
2023/03/07 09:26:12 Job still running ...
2023/03/07 09:26:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-07_01_18_10-14330950567437301559 failed
--- FAIL: TestXLang_Partition (552.40s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3244.569s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678177996289829728
--- FAIL: TestBigQueryIO_BasicWriteRead (4.61s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45453 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gNeobXhVyQ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gNeobXhVyQ"}}  windowing_strategies:{key:"w0@gNeobXhVyQ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gNeobXhVyQ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gNeobXhVyQ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gNeobXhVyQ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678177996289829728\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gNeobXhVyQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45453 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gNeobXhVyQ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gNeobXhVyQ"}}  windowing_strategies:{key:"w0@gNeobXhVyQ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gNeobXhVyQ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gNeobXhVyQ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gNeobXhVyQ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678177996289829728\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gNeobXhVyQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6c900, 0xc0004869c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c900, 0xc0004869c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000488880?, 0xc0000bc280?}, {0x11384d6, 0x39}, {0xc0000f0180?, 0xa9cba0?, 0x1?}, {0xc000123af0, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488820?, 0xc0000bc280?}, {0xc00004cd80, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0xe793e0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000123af0, 0xf}, {0xc00004cd80, 0x52}, {0xeba6e0, 0xc00048a1a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005831e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005831e0, 0x116a4c8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.644s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.052s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:922dc6f23a4f49db097ea6d63668c7ac154cb03291bccb1d04772d35027a146a
  Associated tags:
 - 20230307-083231
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-083231
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-083231].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:922dc6f23a4f49db097ea6d63668c7ac154cb03291bccb1d04772d35027a146a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307082035]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b71508fdc92167687f8f16c83b5434217a0d08790e9757036783a863b8e8721c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307082035] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b71508fdc92167687f8f16c83b5434217a0d08790e9757036783a863b8e8721c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b71508fdc92167687f8f16c83b5434217a0d08790e9757036783a863b8e8721c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b71508fdc92167687f8f16c83b5434217a0d08790e9757036783a863b8e8721c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307082035]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a896d0a223cc6fdd26bc69ef91c6a4179de14a42c8e25d33cbbd24ae2d985f4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307082035] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a896d0a223cc6fdd26bc69ef91c6a4179de14a42c8e25d33cbbd24ae2d985f4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a896d0a223cc6fdd26bc69ef91c6a4179de14a42c8e25d33cbbd24ae2d985f4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0a896d0a223cc6fdd26bc69ef91c6a4179de14a42c8e25d33cbbd24ae2d985f4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 9s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1371

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1371/display/redirect>

Changes:


------------------------------------------
[...truncated 1021.90 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-023349",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307022045",
            "environmentId": "gCNEFoEMudbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-023349"
      }
    ]
  },
  "name": "go-testxlang_partition-376",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/07 03:19:44 Submitted job: 2023-03-06_19_19_44-14921239488715540967
2023/03/07 03:19:44 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-06_19_19_44-14921239488715540967?project=apache-beam-testing
2023/03/07 03:19:44 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-06_19_19_44-14921239488715540967
2023/03/07 03:19:44 Job state: JOB_STATE_PENDING ...
2023/03/07 03:20:14 Job still running ...
2023/03/07 03:20:44 Job still running ...
2023/03/07 03:21:14 Job still running ...
2023/03/07 03:21:44 Job still running ...
2023/03/07 03:22:14 Job still running ...
2023/03/07 03:22:45 Job still running ...
2023/03/07 03:23:15 Job still running ...
2023/03/07 03:23:45 Job still running ...
2023/03/07 03:24:15 Job still running ...
2023/03/07 03:24:45 Job still running ...
2023/03/07 03:25:15 Job still running ...
2023/03/07 03:25:45 Job still running ...
2023/03/07 03:26:15 Job still running ...
2023/03/07 03:26:45 Job still running ...
2023/03/07 03:27:15 Job still running ...
2023/03/07 03:27:45 Job still running ...
2023/03/07 03:28:15 Job still running ...
2023/03/07 03:28:45 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-06_19_19_44-14921239488715540967 failed
--- FAIL: TestXLang_Partition (580.98s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3273.352s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678156485589559319
--- FAIL: TestBigQueryIO_BasicWriteRead (4.94s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45425 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dnpjpOgCra"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dnpjpOgCra"}}  windowing_strategies:{key:"w0@dnpjpOgCra"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dnpjpOgCra"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dnpjpOgCra"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dnpjpOgCra"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678156485589559319\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dnpjpOgCra"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45425 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dnpjpOgCra"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dnpjpOgCra"}}  windowing_strategies:{key:"w0@dnpjpOgCra"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dnpjpOgCra"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dnpjpOgCra"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dnpjpOgCra"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678156485589559319\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dnpjpOgCra"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 55 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000174fc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000174fc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010ef00?, 0xc0001387d0?}, {0x1138176, 0x39}, {0xc0000f00c0?, 0xa9cba0?, 0x1?}, {0xc000482d00, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010eea0?, 0xc0001387d0?}, {0xc0005ba420, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000482d00, 0xf}, {0xc0005ba420, 0x52}, {0xeba5c0, 0xc000126fc8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.977s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ced824f76cba3aa5ddb572605bebb8047c4db5854e1b7106d79d12a0ac787f88
  Associated tags:
 - 20230307-023349
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-023349
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230307-023349].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ced824f76cba3aa5ddb572605bebb8047c4db5854e1b7106d79d12a0ac787f88].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c98f620330690712e2b726e32522c2501933470d541bec6a9283e92922e1fe74]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230307022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c98f620330690712e2b726e32522c2501933470d541bec6a9283e92922e1fe74])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c98f620330690712e2b726e32522c2501933470d541bec6a9283e92922e1fe74
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c98f620330690712e2b726e32522c2501933470d541bec6a9283e92922e1fe74].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1458b1e9298a4ba521730e7466b47a39646946966b0e2be263a169c7b23cdfbc]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230307022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1458b1e9298a4ba521730e7466b47a39646946966b0e2be263a169c7b23cdfbc])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1458b1e9298a4ba521730e7466b47a39646946966b0e2be263a169c7b23cdfbc
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1458b1e9298a4ba521730e7466b47a39646946966b0e2be263a169c7b23cdfbc].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 1s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1370

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1370/display/redirect>

Changes:


------------------------------------------
[...truncated 571.94 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-203326",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306202034",
            "environmentId": "CPlpuAjjkBbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-203326"
      }
    ]
  },
  "name": "go-testxlang_partition-530",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/06 21:19:03 Submitted job: 2023-03-06_13_19_02-9234894832756901280
2023/03/06 21:19:03 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-06_13_19_02-9234894832756901280?project=apache-beam-testing
2023/03/06 21:19:03 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-06_13_19_02-9234894832756901280
2023/03/06 21:19:03 Job state: JOB_STATE_PENDING ...
2023/03/06 21:19:33 Job still running ...
2023/03/06 21:20:03 Job still running ...
2023/03/06 21:20:33 Job still running ...
2023/03/06 21:21:03 Job still running ...
2023/03/06 21:21:33 Job still running ...
2023/03/06 21:22:03 Job still running ...
2023/03/06 21:22:33 Job still running ...
2023/03/06 21:23:03 Job still running ...
2023/03/06 21:23:33 Job still running ...
2023/03/06 21:24:03 Job still running ...
2023/03/06 21:24:33 Job still running ...
2023/03/06 21:25:03 Job still running ...
2023/03/06 21:25:33 Job still running ...
2023/03/06 21:26:03 Job still running ...
2023/03/06 21:26:33 Job still running ...
2023/03/06 21:27:03 Job still running ...
2023/03/06 21:27:33 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-06_13_19_02-9234894832756901280 failed
--- FAIL: TestXLang_Partition (551.16s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3242.704s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678134844451798416
--- FAIL: TestBigQueryIO_BasicWriteRead (4.56s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43043 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@mHlLcQsgpT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@mHlLcQsgpT"}}  windowing_strategies:{key:"w0@mHlLcQsgpT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@mHlLcQsgpT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@mHlLcQsgpT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@mHlLcQsgpT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678134844451798416\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"mHlLcQsgpT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43043 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@mHlLcQsgpT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@mHlLcQsgpT"}}  windowing_strategies:{key:"w0@mHlLcQsgpT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@mHlLcQsgpT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@mHlLcQsgpT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@mHlLcQsgpT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678134844451798416\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"mHlLcQsgpT"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00057d740})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00057d740})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168ec0?, 0xc00068a050?}, {0x1138176, 0x39}, {0xc0005ac0c0?, 0xa9cba0?, 0x1?}, {0xc0003f6e90, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168d40?, 0xc00068a050?}, {0xc00055c360, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f1479d037f0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6e90, 0xf}, {0xc00055c360, 0x52}, {0xeba5c0, 0xc00048a130})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003e1520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003e1520, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.598s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92d66a617e4bcdc4e45459c1624a0f3c0806e1d405555610247f079f83dfb135
  Associated tags:
 - 20230306-203326
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-203326
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-203326].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92d66a617e4bcdc4e45459c1624a0f3c0806e1d405555610247f079f83dfb135].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306202034]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d653ad0988f26dcc3b36130e91df30edfe1471b640cc2401fea300669243af6b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306202034] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d653ad0988f26dcc3b36130e91df30edfe1471b640cc2401fea300669243af6b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d653ad0988f26dcc3b36130e91df30edfe1471b640cc2401fea300669243af6b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d653ad0988f26dcc3b36130e91df30edfe1471b640cc2401fea300669243af6b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306202034]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:755a464e973fb5f366ece07132395926da495abfdb7f6aaa2e5d3f8085e99b17]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306202034] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:755a464e973fb5f366ece07132395926da495abfdb7f6aaa2e5d3f8085e99b17])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:755a464e973fb5f366ece07132395926da495abfdb7f6aaa2e5d3f8085e99b17
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:755a464e973fb5f366ece07132395926da495abfdb7f6aaa2e5d3f8085e99b17].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 58s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1369

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1369/display/redirect?page=changes>

Changes:

[noreply] [Spark Dataset runner] Prevent stackoverflow in ParDo load tests when


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306142043",
            "environmentId": "bNrlqLMqIIbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221"
      }
    ]
  },
  "name": "go-testxlang_partition-34",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/06 15:16:54 Submitted job: 2023-03-06_07_16_54-13989843656813190198
2023/03/06 15:16:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-06_07_16_54-13989843656813190198?project=apache-beam-testing
2023/03/06 15:16:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-06_07_16_54-13989843656813190198
2023/03/06 15:16:54 Job state: JOB_STATE_PENDING ...
2023/03/06 15:17:25 Job still running ...
2023/03/06 15:17:55 Job still running ...
2023/03/06 15:18:25 Job still running ...
2023/03/06 15:18:55 Job still running ...
2023/03/06 15:19:25 Job still running ...
2023/03/06 15:19:55 Job still running ...
2023/03/06 15:20:25 Job still running ...
2023/03/06 15:20:55 Job still running ...
2023/03/06 15:21:25 Job still running ...
2023/03/06 15:21:55 Job still running ...
2023/03/06 15:22:25 Job still running ...
2023/03/06 15:22:55 Job still running ...
2023/03/06 15:23:25 Job still running ...
2023/03/06 15:23:55 Job still running ...
2023/03/06 15:24:25 Job still running ...
2023/03/06 15:24:55 Job still running ...
2023/03/06 15:25:26 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-06_07_16_54-13989843656813190198 failed
--- FAIL: TestXLang_Partition (551.29s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3180.820s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678113178603742794
--- FAIL: TestBigQueryIO_BasicWriteRead (4.51s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34723 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PvLndzySLA"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PvLndzySLA"}}  windowing_strategies:{key:"w0@PvLndzySLA"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PvLndzySLA"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PvLndzySLA"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PvLndzySLA"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678113178603742794\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PvLndzySLA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34723 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PvLndzySLA"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PvLndzySLA"}}  windowing_strategies:{key:"w0@PvLndzySLA"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PvLndzySLA"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PvLndzySLA"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PvLndzySLA"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678113178603742794\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PvLndzySLA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0004a9880})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0004a9880})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0006a4fa0?, 0xc000129680?}, {0x1138176, 0x39}, {0xc000172000?, 0xa9cba0?, 0x1?}, {0xc000695340, 0xf}, 0xc00016fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0006a4f40?, 0xc000129680?}, {0xc0006b4540, 0x52}, {0x1?}, {0xc00016fea8, 0x2, 0x7fe141a02448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000695340, 0xf}, {0xc0006b4540, 0x52}, {0xeba5c0, 0xc000043010})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.545s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:99c40e5dc17c6bdbdd4a1eceb0608182075814bfe04a03a92a6e3cffcb380c65
Deleted: sha256:1169a475af82d6e58a27cb5dd2a19dc72d8e667e54de28e06986fd5402c68df1
Deleted: sha256:636d79a6d61b3d63f099bd6e52e07664ecbcc5fc2c26513a303869e2918e77b5
Deleted: sha256:a5cfc8ee95d437f7f5dba82466cc54088f5e0305d89dbb887de575ca5777b735
Deleted: sha256:37fba773a99067c8d59d55e83f0eeb40022ae7f0638dbcd03e2836d3ca7244e6
Deleted: sha256:63e15bcbaf4c1b8e9cfa4c44de38c0b9101db37fcece3544c1f2bb61741997fc
Deleted: sha256:d50450da8ada3d2c83ff16bc5119de05b0f9dc2bec7bb3154eed9527cbd5ba82
Deleted: sha256:6c1391247437fc1b1556117d23c7565dec370dbb348a879ea1d7a1f6c9879ce5
Deleted: sha256:5819e5e19adc8a808ee26c601def81df7168eb1e6b2023a448272fb3f0d1f190
Deleted: sha256:6642f94b9df0b63a9a5d6baa0637a6f30a08b6d97ab01030d990a0be49fb1644
Deleted: sha256:07ddde19583437df72dbee30a4e75fa4ef91099cf21588a12ebd7716a6029d50
Deleted: sha256:cb19943f7d63af83231f80506baf610e5b04f93c2ec51b38154e37614072179a
Deleted: sha256:e6c7b744e4d352ab919745e34134dad4476d1f621838aca17d6fffd9f2a59435
Deleted: sha256:1c78202fb8bec77960daea77ac60aaae098a05d35234325fd8788e9b4888b2d2
Deleted: sha256:45962b29da096b7e32c5070dc28796d5f49a5d94aabeac3a793afd18400d070b
Deleted: sha256:8c64415faaec58dda6915522e781e011fb2dcc242e9fa11b4acf3f2e3ddb7c98
Deleted: sha256:97eaa9120ce8e2e810e10753b9601b2ad5cecbb68b3a3f9d2e2c44babe91cfb8
Deleted: sha256:820dea39cfe812405e3275815ab15c558045f963c8fd145282986e1ce1bfc7af
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:99c40e5dc17c6bdbdd4a1eceb0608182075814bfe04a03a92a6e3cffcb380c65
  Associated tags:
 - 20230306-143221
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-143221].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:99c40e5dc17c6bdbdd4a1eceb0608182075814bfe04a03a92a6e3cffcb380c65].
$ rm -rf /tmp/tmp.T5ov8Q9PMM
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306142043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1743ab931501d2b64bf31bf87c1d07615cdf7fb02e7f45bf0bd332f3d6ccdf42].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306142043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306142043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306142043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98faa3a67d522bc2b2dc1abbb64951e25579ebd972c596310e93c5275ae31930].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 4089730.
Stopping expansion service pid: 4089731.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 42s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/4iovwwxlb3zby

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1368

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1368/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306082039",
            "environmentId": "LEWYXxxyWpbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205"
      }
    ]
  },
  "name": "go-testxlang_partition-762",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/06 09:18:03 Submitted job: 2023-03-06_01_18_03-142268285904422329
2023/03/06 09:18:03 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-06_01_18_03-142268285904422329?project=apache-beam-testing
2023/03/06 09:18:03 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-06_01_18_03-142268285904422329
2023/03/06 09:18:03 Job state: JOB_STATE_PENDING ...
2023/03/06 09:18:33 Job still running ...
2023/03/06 09:19:03 Job still running ...
2023/03/06 09:19:33 Job still running ...
2023/03/06 09:20:03 Job still running ...
2023/03/06 09:20:34 Job still running ...
2023/03/06 09:21:04 Job still running ...
2023/03/06 09:21:34 Job still running ...
2023/03/06 09:22:04 Job still running ...
2023/03/06 09:22:34 Job still running ...
2023/03/06 09:23:04 Job still running ...
2023/03/06 09:23:34 Job still running ...
2023/03/06 09:24:04 Job still running ...
2023/03/06 09:24:34 Job still running ...
2023/03/06 09:25:04 Job still running ...
2023/03/06 09:25:34 Job still running ...
2023/03/06 09:26:04 Job still running ...
2023/03/06 09:26:34 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-06_01_18_03-142268285904422329 failed
--- FAIL: TestXLang_Partition (550.25s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3262.872s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678091564891851346
--- FAIL: TestBigQueryIO_BasicWriteRead (4.69s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34555 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wRYFhCwXrM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wRYFhCwXrM"}}  windowing_strategies:{key:"w0@wRYFhCwXrM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wRYFhCwXrM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wRYFhCwXrM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wRYFhCwXrM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678091564891851346\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wRYFhCwXrM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34555 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wRYFhCwXrM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wRYFhCwXrM"}}  windowing_strategies:{key:"w0@wRYFhCwXrM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wRYFhCwXrM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wRYFhCwXrM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wRYFhCwXrM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678091564891851346\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wRYFhCwXrM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 54 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0006b5040})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0006b5040})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a77c0?, 0xc00051b6d0?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc00011ece0, 0xf}, 0xc0001a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7760?, 0xc00051b6d0?}, {0xc0006a63c0, 0x52}, {0x1?}, {0xc0001a9ea8, 0x2, 0x7f256e4b9bb8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011ece0, 0xf}, {0xc0006a63c0, 0x52}, {0xeba5c0, 0xc00011fff0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.728s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92d2adcff84be3c95351e3379d72e6c5ec15354453b9b42cc1d443183c0f6a5d
Deleted: sha256:8795f6dbbadcdbb973789beecf19ae970002ab88ac0c4e79129f3c0020426206
Deleted: sha256:c6273e5b7ed96a5814ee3270d03dee51b73904ebe3c028dd2b609ae82ea662dc
Deleted: sha256:a39bc9c43b1fc24cd284ec7e116524d37188f7273a0a3fe2f70370b2d7991dcf
Deleted: sha256:51ae0d5f9a3d2c628b101d773c156a15c827f8a6ffdd5def038f22a99997bf42
Deleted: sha256:8658039f8761f6e3b6d4487d0c0efe5c3c7b431f9e06f8ec49540ef19c9420f6
Deleted: sha256:24ad8c48d4d86b54ae0e2715a347c1159ea6a17b9f4ed63e123a685d82991eb0
Deleted: sha256:ee61ab462ae2e5fa50abc5425689934c1b15f50804574431ff1ecab12821d07d
Deleted: sha256:289662948bf92e516e39e98fafd0e3b8ab4a8cb3cc9309d2abbde5c3c09be09b
Deleted: sha256:dcfc6e5b31c902afba4af5d2786e8849dd77c790294aa45163b0578862d9ad71
Deleted: sha256:1b4f71d9da96d14752f8fa1daa7076b1431a3b041379d683f381c09d9528e772
Deleted: sha256:5cbbd5a50e5ef758464c14b12e42d860144e9adddcdffebfc947206a2101ad05
Deleted: sha256:22bbdb881f0783ccf95311b38b5eaf40b67e6ce216f6e766ac898181ea07a115
Deleted: sha256:afa45293552e91770785f09a4297e2f126e2c4d170e601ef5f7ef84a01a99e00
Deleted: sha256:40fe9c8416cf9460b7823d1171b2acb0c871a4fc19ee7c0e13c13e4a78471fb2
Deleted: sha256:8e825cdc251423cc1b41c3e4c1e6b74fbd7b6d62898fc1f3e8f8fcd59dca632a
Deleted: sha256:c0c54ab0d1a38e2ae382232f7b2d06a96caada90154398a670f4d6b5de346f85
Deleted: sha256:3a50fb6155188d72af0c1212d2e01b18b5570dd568602994a51105af173a12f6
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92d2adcff84be3c95351e3379d72e6c5ec15354453b9b42cc1d443183c0f6a5d
  Associated tags:
 - 20230306-083205
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-083205].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92d2adcff84be3c95351e3379d72e6c5ec15354453b9b42cc1d443183c0f6a5d].
$ rm -rf /tmp/tmp.kZVYj72KsD
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306082039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306082039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306082039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c06ba25b24ef16a248a8d002e77d8661380f87283929c5694aae41e9d37ddfd0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306082039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306082039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306082039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:651e6533a031e0775d8293d186dda87332e9b73824dc35a44684f9da56cbf945].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3844229.
Stopping expansion service pid: 3844230.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 51s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1367

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1367/display/redirect>

Changes:


------------------------------------------
[...truncated 1020.25 KB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306022032",
            "environmentId": "bwPTESWhHsbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-023148",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-023148"
      }
    ]
  },
  "name": "go-testxlang_partition-458",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/06 03:16:15 Submitted job: 2023-03-05_19_16_15-7074198758433370695
2023/03/06 03:16:15 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-05_19_16_15-7074198758433370695?project=apache-beam-testing
2023/03/06 03:16:15 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-05_19_16_15-7074198758433370695
2023/03/06 03:16:16 Job state: JOB_STATE_PENDING ...
2023/03/06 03:16:46 Job still running ...
2023/03/06 03:17:16 Job still running ...
2023/03/06 03:17:46 Job still running ...
2023/03/06 03:18:16 Job still running ...
2023/03/06 03:18:46 Job still running ...
2023/03/06 03:19:16 Job still running ...
2023/03/06 03:19:46 Job still running ...
2023/03/06 03:20:16 Job still running ...
2023/03/06 03:20:46 Job still running ...
2023/03/06 03:21:16 Job still running ...
2023/03/06 03:21:46 Job still running ...
2023/03/06 03:22:16 Job still running ...
2023/03/06 03:22:46 Job still running ...
2023/03/06 03:23:16 Job still running ...
2023/03/06 03:23:46 Job still running ...
2023/03/06 03:24:16 Job still running ...
2023/03/06 03:24:46 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-05_19_16_15-7074198758433370695 failed
--- FAIL: TestXLang_Partition (550.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3175.631s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678069944532425418
--- FAIL: TestBigQueryIO_BasicWriteRead (4.36s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45449 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@oRFdvpohRh"  is_bounded:BOUNDED  windowing_strategy_id:"w0@oRFdvpohRh"}}  windowing_strategies:{key:"w0@oRFdvpohRh"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@oRFdvpohRh"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@oRFdvpohRh"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@oRFdvpohRh"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678069944532425418\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"oRFdvpohRh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45449 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@oRFdvpohRh"  is_bounded:BOUNDED  windowing_strategy_id:"w0@oRFdvpohRh"}}  windowing_strategies:{key:"w0@oRFdvpohRh"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@oRFdvpohRh"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@oRFdvpohRh"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@oRFdvpohRh"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678069944532425418\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"oRFdvpohRh"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0004c44c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0004c44c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169940?, 0xc000115b30?}, {0x1138176, 0x39}, {0xc00015c180?, 0xa9cba0?, 0x1?}, {0xc0003f6f60, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001698e0?, 0xc000115b30?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7f2109074b20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6f60, 0xf}, {0xc00004c5a0, 0x52}, {0xeba5c0, 0xc00017e500})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582d00, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.399s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3593d0e8a7c0aedc055ff5c007ce91a3bf30f5108d7bc4d70f7f9a6670d3f04a
  Associated tags:
 - 20230306-023148
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-023148
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230306-023148].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3593d0e8a7c0aedc055ff5c007ce91a3bf30f5108d7bc4d70f7f9a6670d3f04a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306022032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:365bb03effc9075adc4671dd1c7d823114d2540ff83d829ee72a96d1e32b769a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230306022032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:365bb03effc9075adc4671dd1c7d823114d2540ff83d829ee72a96d1e32b769a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:365bb03effc9075adc4671dd1c7d823114d2540ff83d829ee72a96d1e32b769a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:365bb03effc9075adc4671dd1c7d823114d2540ff83d829ee72a96d1e32b769a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306022032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5f822f54379979e557ff1a88fbb1a1dafb21d338f34e529a0ad1c88624ca23a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230306022032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5f822f54379979e557ff1a88fbb1a1dafb21d338f34e529a0ad1c88624ca23a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5f822f54379979e557ff1a88fbb1a1dafb21d338f34e529a0ad1c88624ca23a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d5f822f54379979e557ff1a88fbb1a1dafb21d338f34e529a0ad1c88624ca23a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 11s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1366

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1366/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305202032",
            "environmentId": "EjXDocVDyxbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209"
      }
    ]
  },
  "name": "go-testxlang_partition-506",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/05 21:17:44 Submitted job: 2023-03-05_13_17_43-82472456185949293
2023/03/05 21:17:44 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-05_13_17_43-82472456185949293?project=apache-beam-testing
2023/03/05 21:17:44 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-05_13_17_43-82472456185949293
2023/03/05 21:17:44 Job state: JOB_STATE_PENDING ...
2023/03/05 21:18:14 Job still running ...
2023/03/05 21:18:44 Job still running ...
2023/03/05 21:19:14 Job still running ...
2023/03/05 21:19:44 Job still running ...
2023/03/05 21:20:14 Job still running ...
2023/03/05 21:20:44 Job still running ...
2023/03/05 21:21:14 Job still running ...
2023/03/05 21:21:44 Job still running ...
2023/03/05 21:22:14 Job still running ...
2023/03/05 21:22:44 Job still running ...
2023/03/05 21:23:14 Job still running ...
2023/03/05 21:23:44 Job still running ...
2023/03/05 21:24:14 Job still running ...
2023/03/05 21:24:44 Job still running ...
2023/03/05 21:25:14 Job still running ...
2023/03/05 21:25:44 Job still running ...
2023/03/05 21:26:14 Job still running ...
2023/03/05 21:26:45 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-05_13_17_43-82472456185949293 failed
--- FAIL: TestXLang_Partition (580.04s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3270.739s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678048367763947917
--- FAIL: TestBigQueryIO_BasicWriteRead (4.75s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38855 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@DaaDaNpFgd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@DaaDaNpFgd"}}  windowing_strategies:{key:"w0@DaaDaNpFgd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@DaaDaNpFgd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@DaaDaNpFgd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@DaaDaNpFgd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678048367763947917\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"DaaDaNpFgd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38855 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@DaaDaNpFgd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@DaaDaNpFgd"}}  windowing_strategies:{key:"w0@DaaDaNpFgd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@DaaDaNpFgd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@DaaDaNpFgd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@DaaDaNpFgd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678048367763947917\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"DaaDaNpFgd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0002e5580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0002e5580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000688360?, 0xc0000fc050?}, {0x1138176, 0x39}, {0xc00015c180?, 0xa9cba0?, 0x1?}, {0xc00048ace0, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000688300?, 0xc0000fc050?}, {0xc000696540, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7fb4145b55d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ace0, 0xf}, {0xc000696540, 0x52}, {0xeba5c0, 0xc0006a22f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a9040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a9040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.788s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.039s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f17919b4683e76f2371b1afe3e208af8fc928fdd807b0a67707bbbd523d2573
Deleted: sha256:8518d9142286e73315e42a779f5ebb7476c8d9867c9ff7ab1114ed78812e771d
Deleted: sha256:5d9297dc3a4f0fb1099de46a837790b575099d162315a3d88269accb0f88be1d
Deleted: sha256:e39dd5cb7c9cda4f942a883bf96e4e33693e3b9ee6f9d2442f993c4ff111a8dc
Deleted: sha256:e75d2ec6b522f7c2b3497b67d839ded7f7e04803c3dfb434bdf57e2003834c85
Deleted: sha256:3fa0e0595c18a66be713bee29ebd0c66e3ea9cbc4ec598d6e12fc76cb561f682
Deleted: sha256:1eb16212fc8ca8e4f737cd85c2ac341c1f34cd97ca62550de49daa992d1e592c
Deleted: sha256:aa399ce61bcc2f29525db51dda2a17b7c17d8aa400790533123b4ec57fce88c7
Deleted: sha256:269f05716dd65ea88d94d1f127d4350aca476569759f41102091271f674bf1dd
Deleted: sha256:30f168de7e0923eaeb5a033d13f4534d34ad563ce398abd2853a9a31cc26f4d7
Deleted: sha256:aa45609c42cfd9573d94cda57e42fdd4d4f4ac9c190ce729c38d073493f823de
Deleted: sha256:aca9c95c46c757f83acf9a4e420ce6b7e4c7055104ba92520f7ac96678439396
Deleted: sha256:e77608ad3fd86dc28060d8eecfeae9680138b39d0571582ffa4de3eb9a9d3810
Deleted: sha256:b83ec83ef50999ff9c974679fb40ecb2fef4bc1ee836b74beedbadd1e6e2440a
Deleted: sha256:6da6125de061b9db3ce0a56cefddbb41014f78467c942cb3cd1228032a8d439e
Deleted: sha256:f9c1f84661538be73c00b99fd33da36d0b94c4e328ec08d082fabb66b2ca4242
Deleted: sha256:242963f9065c6539dc274e39f4cd93e693c5cff71cbd0caf07296a87cf08333d
Deleted: sha256:533e730dbed2a2193ac0fae3e55007741bd2f05eda14751a16dd8508042460af
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f17919b4683e76f2371b1afe3e208af8fc928fdd807b0a67707bbbd523d2573
  Associated tags:
 - 20230305-203209
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-203209].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3f17919b4683e76f2371b1afe3e208af8fc928fdd807b0a67707bbbd523d2573].
$ rm -rf /tmp/tmp.MR8ivti5CZ
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305202032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e220eea6f190d517f3d9547796a20f2284286a42f6c68addfa8cd48b498dbd7e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305202032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:483908ee40890e9b2c27541a1b058358b5347f4ae17474461a5b5412fc10f414].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3328083.
Stopping expansion service pid: 3328084.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 9s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1365

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1365/display/redirect>

Changes:


------------------------------------------
[...truncated 1019.54 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305142038",
            "environmentId": "RXeelCtZFebeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157"
      }
    ]
  },
  "name": "go-testxlang_partition-455",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/05 15:16:26 Submitted job: 2023-03-05_07_16_26-4416427312657002756
2023/03/05 15:16:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-05_07_16_26-4416427312657002756?project=apache-beam-testing
2023/03/05 15:16:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-05_07_16_26-4416427312657002756
2023/03/05 15:16:26 Job state: JOB_STATE_PENDING ...
2023/03/05 15:16:57 Job still running ...
2023/03/05 15:17:27 Job still running ...
2023/03/05 15:17:57 Job still running ...
2023/03/05 15:18:27 Job still running ...
2023/03/05 15:18:57 Job still running ...
2023/03/05 15:19:27 Job still running ...
2023/03/05 15:19:57 Job still running ...
2023/03/05 15:20:27 Job still running ...
2023/03/05 15:20:57 Job still running ...
2023/03/05 15:21:27 Job still running ...
2023/03/05 15:21:57 Job still running ...
2023/03/05 15:22:27 Job still running ...
2023/03/05 15:22:57 Job still running ...
2023/03/05 15:23:27 Job still running ...
2023/03/05 15:23:57 Job still running ...
2023/03/05 15:24:27 Job still running ...
2023/03/05 15:24:57 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-05_07_16_26-4416427312657002756 failed
--- FAIL: TestXLang_Partition (550.30s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3177.527s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678026753816832082
--- FAIL: TestBigQueryIO_BasicWriteRead (4.55s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45157 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@vKFenAoxHz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@vKFenAoxHz"}}  windowing_strategies:{key:"w0@vKFenAoxHz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@vKFenAoxHz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@vKFenAoxHz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@vKFenAoxHz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678026753816832082\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"vKFenAoxHz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45157 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@vKFenAoxHz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@vKFenAoxHz"}}  windowing_strategies:{key:"w0@vKFenAoxHz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@vKFenAoxHz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@vKFenAoxHz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@vKFenAoxHz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678026753816832082\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"vKFenAoxHz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0000f32c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0000f32c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048c980?, 0xc0000ba0a0?}, {0x1138176, 0x39}, {0xc0002080c0?, 0xa9cba0?, 0x1?}, {0xc000681010, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048c920?, 0xc0000ba0a0?}, {0xc0005f0300, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7fccb0125a78?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000681010, 0xf}, {0xc0005f0300, 0x52}, {0xeba5c0, 0xc0005ce3b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000496ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000496ea0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.590s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:787c15207c50b6fa09fc41ec8b04855d947bbef274f9335b99e9d643c99fef1d
Deleted: sha256:92a641299cc25000b5bc6ad6ebc288e8a1024f9d67a57acf80498c97196f8aa4
Deleted: sha256:570d23d2226bea72c0d78f2e4cc76810c715c0517fb0504b782531602cb70f61
Deleted: sha256:e4b246b50d54d78f574278b9a5b5e4ae915211cce591774e1a43c3fd5f386acb
Deleted: sha256:d5b8413d6e6f2a513de142c51f727eb33ddb7375ea5515389acb48c4375dda41
Deleted: sha256:7f32699b19023f63cb1ad8bcbae12b9828c9c58e516d9d32946f90266c6aa4b7
Deleted: sha256:5222f985b205d22d696732a734e2dcd692eebee0e5d27927f979637020708aee
Deleted: sha256:a61aa219658c73e921d043a74642f1dd547298d788f666c2cb648f318a854300
Deleted: sha256:2a1799f1175db88fdd0f4289a2d0413f3a830171686ecd34f76666ef1ad1f0aa
Deleted: sha256:f048efbaec7afb63470d22a6b4d4260332f23c43580d7323d2c4adbf27c20b6e
Deleted: sha256:43d30e9affc7d02c37dbc3e3033589828c85734268b857709316aef5c62f2369
Deleted: sha256:3f9e23d9b33addcd250a7af6ea16c5508e866dcc5deac97870920e98ef90d22b
Deleted: sha256:583cb3498e8ec3ae83c81ccf6086654e8a2167a6f1de43283e34344e5548fac6
Deleted: sha256:9ad466d06938f1264bc85b98dd3d1256ea35e020c32dd9e795c1f21ffee83c2b
Deleted: sha256:06d1f0ec817b76bf24331336787660e689e1ba2c9ab94eefa714f726ea365e54
Deleted: sha256:fa2686d84524fb9ce938071c05fcb29ba96dda94250e0081a1e9c36cf71a70c1
Deleted: sha256:1f6b042cee265429806b882d494f98b6493d5037016c95ce641b5da1a83cf074
Deleted: sha256:64dc5ae783c788ddcf3bf480a65895e9b70d096cc718e45b0957ed99584da795
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:787c15207c50b6fa09fc41ec8b04855d947bbef274f9335b99e9d643c99fef1d
  Associated tags:
 - 20230305-143157
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-143157].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:787c15207c50b6fa09fc41ec8b04855d947bbef274f9335b99e9d643c99fef1d].
$ rm -rf /tmp/tmp.lxJlJ4XKsd
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:268753a325c152ad5aec15e248a0fb7e91655d4c648c4f392fddb0f96fcf40bb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305142038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305142038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305142038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86350ef395f573ea41d3d3a4a360ec7d8914401845c4b1bbbb7d26959150e54f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3223838.
Stopping expansion service pid: 3223839.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 15s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1364

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1364/display/redirect>

Changes:


------------------------------------------
[...truncated 569.46 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-083236",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305082028",
            "environmentId": "zFKMDfwGKWbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-083236"
      }
    ]
  },
  "name": "go-testxlang_partition-512",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/05 09:19:10 Submitted job: 2023-03-05_01_19_09-11448947837782830637
2023/03/05 09:19:10 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-05_01_19_09-11448947837782830637?project=apache-beam-testing
2023/03/05 09:19:10 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-05_01_19_09-11448947837782830637
2023/03/05 09:19:10 Job state: JOB_STATE_PENDING ...
2023/03/05 09:19:40 Job still running ...
2023/03/05 09:20:10 Job still running ...
2023/03/05 09:20:40 Job still running ...
2023/03/05 09:21:10 Job still running ...
2023/03/05 09:21:40 Job still running ...
2023/03/05 09:22:10 Job still running ...
2023/03/05 09:22:40 Job still running ...
2023/03/05 09:23:10 Job still running ...
2023/03/05 09:23:40 Job still running ...
2023/03/05 09:24:10 Job still running ...
2023/03/05 09:24:41 Job still running ...
2023/03/05 09:25:11 Job still running ...
2023/03/05 09:25:41 Job still running ...
2023/03/05 09:26:11 Job still running ...
2023/03/05 09:26:41 Job still running ...
2023/03/05 09:27:11 Job still running ...
2023/03/05 09:27:41 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-05_01_19_09-11448947837782830637 failed
--- FAIL: TestXLang_Partition (550.33s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3301.538s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678005192911913097
--- FAIL: TestBigQueryIO_BasicWriteRead (4.60s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36669 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@fkjZlZZYpp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@fkjZlZZYpp"}}  windowing_strategies:{key:"w0@fkjZlZZYpp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@fkjZlZZYpp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@fkjZlZZYpp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@fkjZlZZYpp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678005192911913097\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"fkjZlZZYpp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36669 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@fkjZlZZYpp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@fkjZlZZYpp"}}  windowing_strategies:{key:"w0@fkjZlZZYpp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@fkjZlZZYpp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@fkjZlZZYpp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@fkjZlZZYpp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1678005192911913097\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"fkjZlZZYpp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0002e52c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0002e52c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004eae20?, 0xc00012f680?}, {0x1138176, 0x39}, {0xc000290000?, 0xa9cba0?, 0x1?}, {0xc000043dc0, 0xf}, 0xc000207d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004eadc0?, 0xc00012f680?}, {0xc0004f23c0, 0x52}, {0x1?}, {0xc000207ea8, 0x2, 0x7f8a24b0bc10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043dc0, 0xf}, {0xc0004f23c0, 0x52}, {0xeba5c0, 0xc0001950e0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000462ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000462ea0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.639s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.044s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4e0ffcae1a2bf25081df90ec27d6cd9a8cbe0ace783762fadb675d492169cd03
  Associated tags:
 - 20230305-083236
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-083236
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-083236].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4e0ffcae1a2bf25081df90ec27d6cd9a8cbe0ace783762fadb675d492169cd03].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20184cdd06f2bc7940544ce7303f974ecc6a0791e27c73b95f53bf11b8666342]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20184cdd06f2bc7940544ce7303f974ecc6a0791e27c73b95f53bf11b8666342])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20184cdd06f2bc7940544ce7303f974ecc6a0791e27c73b95f53bf11b8666342
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:20184cdd06f2bc7940544ce7303f974ecc6a0791e27c73b95f53bf11b8666342].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256ded9ab8d2dceaa9c415a509265c98eb687989106682a28d5679a98071f727]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256ded9ab8d2dceaa9c415a509265c98eb687989106682a28d5679a98071f727])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256ded9ab8d2dceaa9c415a509265c98eb687989106682a28d5679a98071f727
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256ded9ab8d2dceaa9c415a509265c98eb687989106682a28d5679a98071f727].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 9s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1363

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1363/display/redirect>

Changes:


------------------------------------------
[...truncated 1019.25 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-023157",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305022038",
            "environmentId": "QKInfOwGoIbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-023157"
      }
    ]
  },
  "name": "go-testxlang_partition-126",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/05 03:16:25 Submitted job: 2023-03-04_19_16_24-16984959361822491748
2023/03/05 03:16:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-04_19_16_24-16984959361822491748?project=apache-beam-testing
2023/03/05 03:16:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-04_19_16_24-16984959361822491748
2023/03/05 03:16:25 Job state: JOB_STATE_PENDING ...
2023/03/05 03:16:55 Job still running ...
2023/03/05 03:17:25 Job still running ...
2023/03/05 03:17:55 Job still running ...
2023/03/05 03:18:25 Job still running ...
2023/03/05 03:18:55 Job still running ...
2023/03/05 03:19:25 Job still running ...
2023/03/05 03:19:55 Job still running ...
2023/03/05 03:20:26 Job still running ...
2023/03/05 03:20:56 Job still running ...
2023/03/05 03:21:26 Job still running ...
2023/03/05 03:21:56 Job still running ...
2023/03/05 03:22:26 Job still running ...
2023/03/05 03:22:56 Job still running ...
2023/03/05 03:23:26 Job still running ...
2023/03/05 03:23:56 Job still running ...
2023/03/05 03:24:26 Job still running ...
2023/03/05 03:24:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-04_19_16_24-16984959361822491748 failed
--- FAIL: TestXLang_Partition (551.05s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3176.446s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677983553652864629
--- FAIL: TestBigQueryIO_BasicWriteRead (4.48s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38421 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@eGRmgOzuYR"  is_bounded:BOUNDED  windowing_strategy_id:"w0@eGRmgOzuYR"}}  windowing_strategies:{key:"w0@eGRmgOzuYR"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@eGRmgOzuYR"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@eGRmgOzuYR"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@eGRmgOzuYR"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677983553652864629\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"eGRmgOzuYR"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38421 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@eGRmgOzuYR"  is_bounded:BOUNDED  windowing_strategy_id:"w0@eGRmgOzuYR"}}  windowing_strategies:{key:"w0@eGRmgOzuYR"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@eGRmgOzuYR"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@eGRmgOzuYR"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@eGRmgOzuYR"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677983553652864629\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"eGRmgOzuYR"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 53 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0005cb2c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0005cb2c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001696c0?, 0xc0001159f0?}, {0x1138176, 0x39}, {0xc00024e000?, 0xa9cba0?, 0x1?}, {0xc0005a0f90, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169660?, 0xc0001159f0?}, {0xc0005e0540, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f5fc468b888?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005a0f90, 0xf}, {0xc0005e0540, 0x52}, {0xeba5c0, 0xc000134810})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000d2ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000d2ea0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.516s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:89dd39bad5236bcbef3fb56b4052e6c204603ea81661edc89c22d4e04c5a7ee3
  Associated tags:
 - 20230305-023157
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-023157
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230305-023157].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:89dd39bad5236bcbef3fb56b4052e6c204603ea81661edc89c22d4e04c5a7ee3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a1e9c6faf8681590f490cc44afe82b1c64477f0b21a20f6c12ce5cd1bec325c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230305022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a1e9c6faf8681590f490cc44afe82b1c64477f0b21a20f6c12ce5cd1bec325c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a1e9c6faf8681590f490cc44afe82b1c64477f0b21a20f6c12ce5cd1bec325c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8a1e9c6faf8681590f490cc44afe82b1c64477f0b21a20f6c12ce5cd1bec325c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305022038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b43c755c5678d1ce2d617f30945533d9437d067253cc83c6be8d704a89ae3d35]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230305022038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b43c755c5678d1ce2d617f30945533d9437d067253cc83c6be8d704a89ae3d35])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b43c755c5678d1ce2d617f30945533d9437d067253cc83c6be8d704a89ae3d35
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b43c755c5678d1ce2d617f30945533d9437d067253cc83c6be8d704a89ae3d35].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 13s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1362

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1362/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304202040",
            "environmentId": "cWrokrVtRpbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158"
      }
    ]
  },
  "name": "go-testxlang_partition-26",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/04 21:16:26 Submitted job: 2023-03-04_13_16_25-13490661587493231115
2023/03/04 21:16:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-04_13_16_25-13490661587493231115?project=apache-beam-testing
2023/03/04 21:16:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-04_13_16_25-13490661587493231115
2023/03/04 21:16:26 Job state: JOB_STATE_PENDING ...
2023/03/04 21:16:56 Job still running ...
2023/03/04 21:17:26 Job still running ...
2023/03/04 21:17:56 Job still running ...
2023/03/04 21:18:26 Job still running ...
2023/03/04 21:18:56 Job still running ...
2023/03/04 21:19:26 Job still running ...
2023/03/04 21:19:56 Job still running ...
2023/03/04 21:20:26 Job still running ...
2023/03/04 21:20:56 Job still running ...
2023/03/04 21:21:26 Job still running ...
2023/03/04 21:21:56 Job still running ...
2023/03/04 21:22:26 Job still running ...
2023/03/04 21:22:56 Job still running ...
2023/03/04 21:23:26 Job still running ...
2023/03/04 21:23:56 Job still running ...
2023/03/04 21:24:26 Job still running ...
2023/03/04 21:24:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-04_13_16_25-13490661587493231115 failed
--- FAIL: TestXLang_Partition (550.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3174.975s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677961955219753974
--- FAIL: TestBigQueryIO_BasicWriteRead (4.37s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45565 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@FzFGfJLlII"  is_bounded:BOUNDED  windowing_strategy_id:"w0@FzFGfJLlII"}}  windowing_strategies:{key:"w0@FzFGfJLlII"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@FzFGfJLlII"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@FzFGfJLlII"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@FzFGfJLlII"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677961955219753974\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"FzFGfJLlII"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45565 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@FzFGfJLlII"  is_bounded:BOUNDED  windowing_strategy_id:"w0@FzFGfJLlII"}}  windowing_strategies:{key:"w0@FzFGfJLlII"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@FzFGfJLlII"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@FzFGfJLlII"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@FzFGfJLlII"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677961955219753974\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"FzFGfJLlII"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0001c7a40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0001c7a40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000498e00?, 0xc0000b99f0?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc0003fcd60, 0xf}, 0xc0005fbd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000498da0?, 0xc0000b99f0?}, {0xc00059a300, 0x52}, {0x1?}, {0xc0005fbea8, 0x2, 0x7fcb2c51d748?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fcd60, 0xf}, {0xc00059a300, 0x52}, {0xeba5c0, 0xc0001be070})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004836c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004836c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.402s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4c890782271ae211dbd969dd06a67f5b01d9bd221e073f997ce1e5e469a5bbf7
Deleted: sha256:0778f8020d14f7889f9f0c603e6e066048aed6b91eb1f3a2ca534942827b43cd
Deleted: sha256:253dc850d71a8ceff891dbc0f10be020fc9caab0513edea0201e28b2c98ae4bc
Deleted: sha256:092f99f6bfef5627ae6c2192ba3eda8e71803bc4b4c342dc449f5ce005bebb35
Deleted: sha256:4b3615145d5b2f1bf074be42acf8b46b00e5bf84d6e90f47c8c43103f03deae7
Deleted: sha256:957854304dced0b533859ec52c7eb14ad80febf4687d641a72e3a9de2688fee2
Deleted: sha256:fb4e87fba3d2a6ed83438d992473bc2a909886ed0385d36288b7cdb1a64d93da
Deleted: sha256:3a1367c0e24406da99ac89adb6479a6a5495325b83b0a77bb891b2c036a8d6ab
Deleted: sha256:81260fcc9c616a966f8fe96b39a69bc2a4610965d0ea586ad67c497b5e16470d
Deleted: sha256:2d41cb427227b880a775a02f311d9a2f1e7d48fa43879be0cf5e069207ccda38
Deleted: sha256:cf1a63b663dcd35440fa3b78cd2ef2498a49485c9184af4071229a83c4013c5b
Deleted: sha256:aedd54767d2bb187a7176d256362433cac54216293c7ee4d699d5d04f131e655
Deleted: sha256:318050cd497e1d505b877d0497adc896d2b57e4ca926dae8194708ea1dfb438c
Deleted: sha256:1d924548e74cc034cc4d673b431557a2b6a18873dde2a5db07564ebfc0c9f4f1
Deleted: sha256:4f95e32bda04f1af6fd658a3194fc4280e340a44214e602721b0aa1604e304fc
Deleted: sha256:1e85d1ca3c0b2d4c73094069eb7f60caf667845b42c4ce85935ff5a187bfce5f
Deleted: sha256:94329d40e4d3b78f04cd93d1a547e649127899f2056878eafab0c5d7101aac61
Deleted: sha256:94b13b1c7b63280e33ceb0bc901ce892f56572ded87f3895e319698e6d4f85b1
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4c890782271ae211dbd969dd06a67f5b01d9bd221e073f997ce1e5e469a5bbf7
  Associated tags:
 - 20230304-203158
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-203158].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4c890782271ae211dbd969dd06a67f5b01d9bd221e073f997ce1e5e469a5bbf7].
$ rm -rf /tmp/tmp.0YgilgI0UW
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1faf00aecf57bb51a0adec0926a1887b49abd2ad97d9cca3c6edb6bda8405a10].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c79e8d69b9738d076db71bf9adb690ec9cc304487b5cd6cef3a959aac409f3d8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2892712.
Stopping expansion service pid: 2892713.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 11s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1361

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1361/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304142030",
            "environmentId": "zCDrtbwAhsbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129"
      }
    ]
  },
  "name": "go-testxlang_partition-857",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/04 15:16:59 Submitted job: 2023-03-04_07_16_58-5360822207553059358
2023/03/04 15:16:59 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-04_07_16_58-5360822207553059358?project=apache-beam-testing
2023/03/04 15:16:59 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-04_07_16_58-5360822207553059358
2023/03/04 15:16:59 Job state: JOB_STATE_PENDING ...
2023/03/04 15:17:29 Job still running ...
2023/03/04 15:17:59 Job still running ...
2023/03/04 15:18:29 Job still running ...
2023/03/04 15:18:59 Job still running ...
2023/03/04 15:19:29 Job still running ...
2023/03/04 15:19:59 Job still running ...
2023/03/04 15:20:29 Job still running ...
2023/03/04 15:20:59 Job still running ...
2023/03/04 15:21:29 Job still running ...
2023/03/04 15:21:59 Job still running ...
2023/03/04 15:22:29 Job still running ...
2023/03/04 15:22:59 Job still running ...
2023/03/04 15:23:29 Job still running ...
2023/03/04 15:24:00 Job still running ...
2023/03/04 15:24:30 Job still running ...
2023/03/04 15:25:00 Job still running ...
2023/03/04 15:25:30 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-04_07_16_58-5360822207553059358 failed
--- FAIL: TestXLang_Partition (551.26s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3239.705s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677940323975660949
--- FAIL: TestBigQueryIO_BasicWriteRead (4.51s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32777 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZOrOPVjAyb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZOrOPVjAyb"}}  windowing_strategies:{key:"w0@ZOrOPVjAyb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZOrOPVjAyb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZOrOPVjAyb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZOrOPVjAyb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677940323975660949\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZOrOPVjAyb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32777 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZOrOPVjAyb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZOrOPVjAyb"}}  windowing_strategies:{key:"w0@ZOrOPVjAyb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZOrOPVjAyb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZOrOPVjAyb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZOrOPVjAyb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677940323975660949\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZOrOPVjAyb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0000f8d00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0000f8d00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6ec0?, 0xc0005ae190?}, {0x1138176, 0x39}, {0xc0005fe000?, 0xa9cba0?, 0x1?}, {0xc000122dd0, 0xf}, 0xc0000f1d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6ce0?, 0xc0005ae190?}, {0xc00004ca20, 0x52}, {0x1?}, {0xc0000f1ea8, 0x2, 0x7f7b81cac670?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122dd0, 0xf}, {0xc00004ca20, 0x52}, {0xeba5c0, 0xc0005a43e0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103a00, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.545s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.040s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:876749af6fcb18e70fde866af4a6463902ce0543ec6d330a9269787a5ec2ccfb
Deleted: sha256:eeb382b12cc922d241db8d40a07f0414300a9275b8a1e891648067b919e42dd2
Deleted: sha256:3a20c728c5780f391379766f02e1757a0288fef8135618c40cdfdeffa451525e
Deleted: sha256:181c37829fd922cf53b9ba1e9cf4095c453c77ddc343745669b79bde4928dd2b
Deleted: sha256:4177da753ecfe35e1596647c0faeb2e83df2b4227476b50c152c01cb803fa0cc
Deleted: sha256:85583c787504cc6fe71ba5845f22ee8161c9270b6f50a27dc6efb4792e514662
Deleted: sha256:5ec663a73d2966ade877e5ec666e8ba9ba872d6c1e501433ec70d6e0f1f80c2d
Deleted: sha256:217239fc7ca2f9a9018043320b139bb4ac8af7e1d0c8348008d3a1b0f8a3eaee
Deleted: sha256:5a45fd8cebd36c67edb7236bbf95008988a66ca238013216264a8c57a7932ca9
Deleted: sha256:d96e105523278dc0f6aa7b1ed4a86cb2ccccbc276cf888d24d6b81e4b2493e9b
Deleted: sha256:069d7a7b259f89d58f120cdf3c9c9fb0bd8a28c5ae6e01aae12df63ef5b3c9e2
Deleted: sha256:17c465b341bceb338ffe33e1b70cf9b20a3c0d8dd987448205142c6b6c7524eb
Deleted: sha256:1f84889c398d724290d86f61319cfb0c9efafc91e9e733f15d4f57432770b7fe
Deleted: sha256:dc3c5f06980064d205010d0252d7fd6cb4494616def600d9f45f027088338ffa
Deleted: sha256:5e41fd99dfe57d7e0e751a94c420d2138bc5451ccd8d2c715327fda3a3a959ac
Deleted: sha256:d1ac63ea97b676df64f4d8f0aba5058b084f4ca3b64de9ce734e4cc7366594ee
Deleted: sha256:c61ce46194357c9a39dca881e5b48dcf21d2020791414ee04e3ca16665c4ed6c
Deleted: sha256:5b62b9063bc35dd129673698af3d8d177902116925d652cb1c49c2cb82d84b39
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:876749af6fcb18e70fde866af4a6463902ce0543ec6d330a9269787a5ec2ccfb
  Associated tags:
 - 20230304-143129
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-143129].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:876749af6fcb18e70fde866af4a6463902ce0543ec6d330a9269787a5ec2ccfb].
$ rm -rf /tmp/tmp.OKSoN0hgKg
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304142030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304142030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304142030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d2091c55bdb4a5dffaf006775a9c02ccfb5bf1104225f334571c772b6487985].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304142030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304142030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304142030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e47e044885c01a6fe401e4f6895b77e634e39043171f9f0189895bbcb3671a3a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2796770.
Stopping expansion service pid: 2796771.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 55s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1360

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1360/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-083150",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304082038",
            "environmentId": "LiQvHeqXRubeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-083150"
      }
    ]
  },
  "name": "go-testxlang_partition-250",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/04 09:16:27 Submitted job: 2023-03-04_01_16_26-5224206188221786902
2023/03/04 09:16:27 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-04_01_16_26-5224206188221786902?project=apache-beam-testing
2023/03/04 09:16:27 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-04_01_16_26-5224206188221786902
2023/03/04 09:16:27 Job state: JOB_STATE_PENDING ...
2023/03/04 09:16:57 Job still running ...
2023/03/04 09:17:27 Job still running ...
2023/03/04 09:17:57 Job still running ...
2023/03/04 09:18:27 Job still running ...
2023/03/04 09:18:57 Job still running ...
2023/03/04 09:19:27 Job still running ...
2023/03/04 09:19:57 Job still running ...
2023/03/04 09:20:27 Job still running ...
2023/03/04 09:20:57 Job still running ...
2023/03/04 09:21:27 Job still running ...
2023/03/04 09:21:57 Job still running ...
2023/03/04 09:22:28 Job still running ...
2023/03/04 09:22:58 Job still running ...
2023/03/04 09:23:28 Job still running ...
2023/03/04 09:23:58 Job still running ...
2023/03/04 09:24:28 Job still running ...
2023/03/04 09:24:58 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-04_01_16_26-5224206188221786902 failed
--- FAIL: TestXLang_Partition (550.59s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3186.261s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677918745211564060
--- FAIL: TestBigQueryIO_BasicWriteRead (4.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39715 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XrPajMRVdg"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XrPajMRVdg"}}  windowing_strategies:{key:"w0@XrPajMRVdg"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XrPajMRVdg"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XrPajMRVdg"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XrPajMRVdg"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677918745211564060\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XrPajMRVdg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39715 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XrPajMRVdg"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XrPajMRVdg"}}  windowing_strategies:{key:"w0@XrPajMRVdg"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XrPajMRVdg"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XrPajMRVdg"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XrPajMRVdg"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677918745211564060\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XrPajMRVdg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0005903c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0005903c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004d2420?, 0xc0004ec000?}, {0x1138176, 0x39}, {0xc0001d2180?, 0xa9cba0?, 0x1?}, {0xc00046cd30, 0xf}, 0xc0001cdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004d23c0?, 0xc0004ec000?}, {0xc000544360, 0x52}, {0x1?}, {0xc0001cdea8, 0x2, 0x7f94c6990b98?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00046cd30, 0xf}, {0xc000544360, 0x52}, {0xeba5c0, 0xc0001aa3a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001031e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001031e0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.572s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e3ff74c3106b92e394e57e6bb3fbc504465ed9db98197c1a8691a4720a08333c
  Associated tags:
 - 20230304-083150
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-083150
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-083150].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e3ff74c3106b92e394e57e6bb3fbc504465ed9db98197c1a8691a4720a08333c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e07bd39903e900c0e9c8c9f4ceca5fa717ca788fee92c4b0512941febbf4384]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e07bd39903e900c0e9c8c9f4ceca5fa717ca788fee92c4b0512941febbf4384])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e07bd39903e900c0e9c8c9f4ceca5fa717ca788fee92c4b0512941febbf4384
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e07bd39903e900c0e9c8c9f4ceca5fa717ca788fee92c4b0512941febbf4384].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b18b7f3bf22a66f081f29cb9d26fc5f638233805b3f2a211b6aa2e9f8dc5d069]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b18b7f3bf22a66f081f29cb9d26fc5f638233805b3f2a211b6aa2e9f8dc5d069])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b18b7f3bf22a66f081f29cb9d26fc5f638233805b3f2a211b6aa2e9f8dc5d069
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b18b7f3bf22a66f081f29cb9d26fc5f638233805b3f2a211b6aa2e9f8dc5d069].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 15s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1359

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1359/display/redirect>

Changes:


------------------------------------------
[...truncated 545.90 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-023201",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304022040",
            "environmentId": "ygYoqSwPBYbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-023201"
      }
    ]
  },
  "name": "go-testxlang_partition-565",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/04 03:17:04 Submitted job: 2023-03-03_19_17_03-2000155064521449771
2023/03/04 03:17:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-03_19_17_03-2000155064521449771?project=apache-beam-testing
2023/03/04 03:17:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-03_19_17_03-2000155064521449771
2023/03/04 03:17:04 Job state: JOB_STATE_PENDING ...
2023/03/04 03:17:34 Job still running ...
2023/03/04 03:18:04 Job still running ...
2023/03/04 03:18:34 Job still running ...
2023/03/04 03:19:04 Job still running ...
2023/03/04 03:19:34 Job still running ...
2023/03/04 03:20:04 Job still running ...
2023/03/04 03:20:34 Job still running ...
2023/03/04 03:21:04 Job still running ...
2023/03/04 03:21:34 Job still running ...
2023/03/04 03:22:04 Job still running ...
2023/03/04 03:22:34 Job still running ...
2023/03/04 03:23:04 Job still running ...
2023/03/04 03:23:34 Job still running ...
2023/03/04 03:24:04 Job still running ...
2023/03/04 03:24:35 Job still running ...
2023/03/04 03:25:05 Job still running ...
2023/03/04 03:25:35 Job still running ...
2023/03/04 03:26:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-03_19_17_03-2000155064521449771 failed
--- FAIL: TestXLang_Partition (580.98s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.352s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677897157237968237
--- FAIL: TestBigQueryIO_BasicWriteRead (4.87s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40593 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@hKeWYifEFb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@hKeWYifEFb"}}  windowing_strategies:{key:"w0@hKeWYifEFb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@hKeWYifEFb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@hKeWYifEFb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@hKeWYifEFb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677897157237968237\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"hKeWYifEFb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40593 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@hKeWYifEFb"  is_bounded:BOUNDED  windowing_strategy_id:"w0@hKeWYifEFb"}}  windowing_strategies:{key:"w0@hKeWYifEFb"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@hKeWYifEFb"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@hKeWYifEFb"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@hKeWYifEFb"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677897157237968237\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"hKeWYifEFb"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000113180})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000113180})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168f20?, 0xc000660050?}, {0x1138176, 0x39}, {0xc0005a80c0?, 0xa9cba0?, 0x1?}, {0xc0003f6d80, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168ec0?, 0xc000660050?}, {0xc00046a3c0, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d80, 0xf}, {0xc00046a3c0, 0x52}, {0xeba5c0, 0xc000042238})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005329c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005329c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.900s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:75a90ff0814f87fc65828db21eb47ccaba613efe4e4ea13db259445cf7c650ff
  Associated tags:
 - 20230304-023201
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-023201
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230304-023201].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:75a90ff0814f87fc65828db21eb47ccaba613efe4e4ea13db259445cf7c650ff].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2be4d3fd46e5c2ff4ec02a89144e5ef02acacaa5033b1b48be232cc01a1530ef]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230304022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2be4d3fd46e5c2ff4ec02a89144e5ef02acacaa5033b1b48be232cc01a1530ef])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2be4d3fd46e5c2ff4ec02a89144e5ef02acacaa5033b1b48be232cc01a1530ef
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2be4d3fd46e5c2ff4ec02a89144e5ef02acacaa5033b1b48be232cc01a1530ef].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b01c88c78f9dbcf7a4466dd7be53ac68c597e8ded67130c71f1b9fa89e784842]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230304022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b01c88c78f9dbcf7a4466dd7be53ac68c597e8ded67130c71f1b9fa89e784842])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b01c88c78f9dbcf7a4466dd7be53ac68c597e8ded67130c71f1b9fa89e784842
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b01c88c78f9dbcf7a4466dd7be53ac68c597e8ded67130c71f1b9fa89e784842].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 21s
232 actionable tasks: 167 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1358

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1358/display/redirect?page=changes>

Changes:

[noreply] Add a 30 second sleep in mass_comment.py to avoid overwhelming Jenkins


------------------------------------------
[...truncated 593.12 KB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303202042",
            "environmentId": "pJJJfiJMfKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248"
      }
    ]
  },
  "name": "go-testxlang_partition-368",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/03 21:22:48 Submitted job: 2023-03-03_13_22_48-13372301449510551783
2023/03/03 21:22:48 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-03_13_22_48-13372301449510551783?project=apache-beam-testing
2023/03/03 21:22:48 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-03_13_22_48-13372301449510551783
2023/03/03 21:22:48 Job state: JOB_STATE_PENDING ...
2023/03/03 21:23:18 Job still running ...
2023/03/03 21:23:48 Job still running ...
2023/03/03 21:24:18 Job still running ...
2023/03/03 21:24:49 Job still running ...
2023/03/03 21:25:19 Job still running ...
2023/03/03 21:25:49 Job still running ...
2023/03/03 21:26:19 Job still running ...
2023/03/03 21:26:49 Job still running ...
2023/03/03 21:27:19 Job still running ...
2023/03/03 21:27:49 Job still running ...
2023/03/03 21:28:19 Job still running ...
2023/03/03 21:28:49 Job still running ...
2023/03/03 21:29:19 Job still running ...
2023/03/03 21:29:49 Job still running ...
2023/03/03 21:30:19 Job still running ...
2023/03/03 21:30:49 Job still running ...
2023/03/03 21:31:19 Job still running ...
2023/03/03 21:31:49 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-03_13_22_48-13372301449510551783 failed
--- FAIL: TestXLang_Partition (580.53s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3537.636s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677875605329228151
--- FAIL: TestBigQueryIO_BasicWriteRead (4.48s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34535 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SOlZctjSER"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SOlZctjSER"}}  windowing_strategies:{key:"w0@SOlZctjSER"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SOlZctjSER"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SOlZctjSER"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SOlZctjSER"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677875605329228151\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SOlZctjSER"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34535 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SOlZctjSER"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SOlZctjSER"}}  windowing_strategies:{key:"w0@SOlZctjSER"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SOlZctjSER"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SOlZctjSER"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SOlZctjSER"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677875605329228151\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SOlZctjSER"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000202c00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000202c00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6f60?, 0xc0000bb6d0?}, {0x1138176, 0x39}, {0xc00015a0c0?, 0xa9cba0?, 0x1?}, {0xc000042e30, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f00?, 0xc0000bb6d0?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0x7fdc4cf3c818?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042e30, 0xf}, {0xc00004c4e0, 0x52}, {0xeba5c0, 0xc000028140})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cab60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cab60, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.514s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:114fc5560fdc2441a4a8cb8b1728dd7d92ebde92342f15fe4ebf8c6ac5fc5032
Deleted: sha256:b6aa4ea597b948232bc3ddef23039be0eaaa55f166b4f54cc598551ee8ccaef1
Deleted: sha256:546516b0d057d8d36ef2779aadd77a3384b6a7e3fe6b8031b3e29c6624a6ca46
Deleted: sha256:970994ed27f106bd2bed72077c289139050034aa467cc0763510965365a5c94b
Deleted: sha256:109f3690f44e3282a04cdbb9bd267f1a2ae524374b55701529e94b1c9a36da3d
Deleted: sha256:1402db1275a2159e2c0e4868d42ca42429405cde62b4f254714801af34a12a38
Deleted: sha256:b58ea79fd6d94bc9117e67dfe89748c71597b4408b655487af8c57d46b64f21c
Deleted: sha256:568563d2a409353a3cb11f2fff7c6a7cd6669c65adedac5d88abd590938cd465
Deleted: sha256:062b659d0df8c26bbf3fd313d1f7b26b280d721f3f31333d669e6b5eef2067db
Deleted: sha256:68d50bfdf9c26bbac1a1cec5cc6ab83f7c1dcc68ca76173f864930cccfa6160f
Deleted: sha256:a71ef26d68088c9e869dc86f5b55906d183dae26d0012720c5b18fec931aebda
Deleted: sha256:ceb7465f556a54a2ae887a58b38edabd6b148d4ecc09666ced3512f4ad4cc572
Deleted: sha256:3282b587e2b043cbec76e4d6219bc4aa76742f979595dec85350f3606de418f6
Deleted: sha256:707da1b2a7693c3dd1a1439310adfa16e8836734db58b7229c1c7229af6a5b5c
Deleted: sha256:f9ed4b6308a61c652e13c4e8edae5726ae6f10fdf0a29340dc4910d0816e6c6f
Deleted: sha256:495cfcc3e94ee208141ef9ad24e78140585b3183dbccf2b33f68a435f7d64e92
Deleted: sha256:77d58610ececaabfa6b9b49d0f6ca7174abec0a6b36c6ffbd659ca0f55f128f8
Deleted: sha256:c86cf850533beca1cd754c993a3d1246389fbda4a187f8697c5ac4c9a24b875d
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:114fc5560fdc2441a4a8cb8b1728dd7d92ebde92342f15fe4ebf8c6ac5fc5032
  Associated tags:
 - 20230303-203248
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-203248].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:114fc5560fdc2441a4a8cb8b1728dd7d92ebde92342f15fe4ebf8c6ac5fc5032].
$ rm -rf /tmp/tmp.RbbdiXxjN3
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7758aef28c25883b3024206ccecfc7c6031dd6d2f880d60f08d91f2a062b103f].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303202042
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303202042]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303202042] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:479bbfb05b7b470807e087ca3d4a20460f6a9268df24d2995683f01f70532b55].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2102935.
Stopping expansion service pid: 2102936.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 12m 3s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1357

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1357/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303142031",
            "environmentId": "PQgAEqJwedbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141"
      }
    ]
  },
  "name": "go-testxlang_partition-199",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/03 15:14:14 Submitted job: 2023-03-03_07_14_13-7986462296623672541
2023/03/03 15:14:14 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-03_07_14_13-7986462296623672541?project=apache-beam-testing
2023/03/03 15:14:14 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-03_07_14_13-7986462296623672541
2023/03/03 15:14:14 Job state: JOB_STATE_PENDING ...
2023/03/03 15:14:44 Job still running ...
2023/03/03 15:15:14 Job still running ...
2023/03/03 15:15:44 Job still running ...
2023/03/03 15:16:14 Job still running ...
2023/03/03 15:16:44 Job still running ...
2023/03/03 15:17:14 Job still running ...
2023/03/03 15:17:44 Job still running ...
2023/03/03 15:18:14 Job still running ...
2023/03/03 15:18:44 Job still running ...
2023/03/03 15:19:14 Job still running ...
2023/03/03 15:19:44 Job still running ...
2023/03/03 15:20:14 Job still running ...
2023/03/03 15:20:44 Job still running ...
2023/03/03 15:21:14 Job still running ...
2023/03/03 15:21:44 Job still running ...
2023/03/03 15:22:14 Job still running ...
2023/03/03 15:22:45 Job still running ...
2023/03/03 15:23:15 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-03_07_14_13-7986462296623672541 failed
--- FAIL: TestXLang_Partition (581.36s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3088.934s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677853939467544441
--- FAIL: TestBigQueryIO_BasicWriteRead (4.63s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38419 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RNftahkHbG"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RNftahkHbG"}}  windowing_strategies:{key:"w0@RNftahkHbG"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RNftahkHbG"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RNftahkHbG"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RNftahkHbG"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677853939467544441\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RNftahkHbG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38419 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RNftahkHbG"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RNftahkHbG"}}  windowing_strategies:{key:"w0@RNftahkHbG"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RNftahkHbG"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RNftahkHbG"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RNftahkHbG"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677853939467544441\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RNftahkHbG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00064e6c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00064e6c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000596e00?, 0xc0000c1680?}, {0x1138176, 0x39}, {0xc00015e0c0?, 0xa9cba0?, 0x1?}, {0xc000137d00, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000596da0?, 0xc0000c1680?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0x7fd1a0bfdb10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137d00, 0xf}, {0xc00004c4e0, 0x52}, {0xeba5c0, 0xc0005f7020})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000538820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000538820, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.669s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7bb21a5c7acbec53edccc8c11e267110350bbdcf37e62a0f5448090ba9dd9623
Deleted: sha256:8bc8de58636be9a1dfcc1ba420547d7cce67962dac5c071f2478d0dc8b72b102
Deleted: sha256:7cf1963df81d3323d047adb5266d55a01f302a834822e622a993be8facf8e134
Deleted: sha256:8aa98ddd9a14bda6f0b3fb204172d3c5b729c66386d2bf6cc9eed98d90701a11
Deleted: sha256:3b32f68e42425fe42dd4a7e941b58fe363dfd6d855e0c5394cd4b823b879f8e2
Deleted: sha256:30f6d47aa674e1630bf01ad7820ba56471cdee6b03f76c6d9e18bc6b64fac607
Deleted: sha256:a817e10e9779be27f4d15b217d95e9ff703f75715ee36d9632bbd3c6bfc710b3
Deleted: sha256:e1492e998f0e18f52d580bd0666fead492ca083c7389ef24bcccabf79c3122f3
Deleted: sha256:8949c4b430ec36b62c8c8df3d49ffbd706ac39f3dac97ba960654e7314eb1863
Deleted: sha256:942c45c90de6e1c87de4ca9c1268e018e27f949ffe0ba215aa743d513c5b2319
Deleted: sha256:7b9e1104c262afe47ae277a52a26c4030886a4ad5d8e492dd8c14f4b6da73ced
Deleted: sha256:2cbc93662f9c72f21bda47f32ca07d20408cf7ecd36f2b6e1f20037fefd04c78
Deleted: sha256:6d2c634efd28c2d528e8abc43942e8ca5661e9223c1dc9c05532faea16a649f2
Deleted: sha256:cf7a41d71f5b70f8a124b4aa8eaf9f5ab752d8a31016cb761b69ad45ed96d2b1
Deleted: sha256:86f2e4a90e9699625a3c921762ba122704f49891054c1ac7cf99d689883b5b60
Deleted: sha256:d8e1bd71bbc17b1ab80ef7ae7d72c626a3c7a15ef71daceeef56345fc7df0164
Deleted: sha256:caed479c8499b36e0312f3f79dc8db7e1949a3092c37c00c34feb02a3edb8f26
Deleted: sha256:46d275c8919c345cf14196b3c338637149e9ac95be986eaae99fa86a25bb0cbf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7bb21a5c7acbec53edccc8c11e267110350bbdcf37e62a0f5448090ba9dd9623
  Associated tags:
 - 20230303-143141
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-143141].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7bb21a5c7acbec53edccc8c11e267110350bbdcf37e62a0f5448090ba9dd9623].
$ rm -rf /tmp/tmp.YO0FUWGc0t
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303142031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303142031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303142031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b2e3efc9e8b1ccab4b44b90caf603fe2877d7febeee423c561c3f429ca539bfe].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303142031
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303142031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303142031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1b9eff8097cefc9345b1fa569c37e77a315f880b56bba6f495adcb65ff7a91cd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1940155.
Stopping expansion service pid: 1940156.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 3m 39s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1356

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1356/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303082039",
            "environmentId": "UXqJAnCIZNbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205"
      }
    ]
  },
  "name": "go-testxlang_partition-889",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/03 09:17:31 Submitted job: 2023-03-03_01_17_31-8119279694955568792
2023/03/03 09:17:31 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-03_01_17_31-8119279694955568792?project=apache-beam-testing
2023/03/03 09:17:31 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-03_01_17_31-8119279694955568792
2023/03/03 09:17:31 Job state: JOB_STATE_PENDING ...
2023/03/03 09:18:01 Job still running ...
2023/03/03 09:18:31 Job still running ...
2023/03/03 09:19:01 Job still running ...
2023/03/03 09:19:31 Job still running ...
2023/03/03 09:20:01 Job still running ...
2023/03/03 09:20:31 Job still running ...
2023/03/03 09:21:01 Job still running ...
2023/03/03 09:21:32 Job still running ...
2023/03/03 09:22:02 Job still running ...
2023/03/03 09:22:32 Job still running ...
2023/03/03 09:23:02 Job still running ...
2023/03/03 09:23:32 Job still running ...
2023/03/03 09:24:02 Job still running ...
2023/03/03 09:24:32 Job still running ...
2023/03/03 09:25:02 Job still running ...
2023/03/03 09:25:32 Job still running ...
2023/03/03 09:26:02 Job still running ...
2023/03/03 09:26:32 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-03_01_17_31-8119279694955568792 failed
--- FAIL: TestXLang_Partition (580.03s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3264.852s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677832360931049289
--- FAIL: TestBigQueryIO_BasicWriteRead (4.58s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44009 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lINogBIPhQ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lINogBIPhQ"}}  windowing_strategies:{key:"w0@lINogBIPhQ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lINogBIPhQ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lINogBIPhQ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lINogBIPhQ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677832360931049289\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lINogBIPhQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44009 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lINogBIPhQ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lINogBIPhQ"}}  windowing_strategies:{key:"w0@lINogBIPhQ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lINogBIPhQ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lINogBIPhQ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lINogBIPhQ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677832360931049289\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lINogBIPhQ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0004da7c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0004da7c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6d40?, 0xc0001b19a0?}, {0x1138176, 0x39}, {0xc0001d20c0?, 0xa9cba0?, 0x1?}, {0xc000042d30, 0xf}, 0xc000173d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6ce0?, 0xc0001b19a0?}, {0xc00053e300, 0x52}, {0x1?}, {0xc000173ea8, 0x2, 0x7f4dd063bc20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d30, 0xf}, {0xc00053e300, 0x52}, {0xeba5c0, 0xc0001a8140})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004cc4e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004cc4e0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.618s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:31f34f1f115161d46df461529111467d583290f8fbf8fa5ae83e47922d8e2063
Deleted: sha256:5c14bd7ddbca6693f05911876a4b70f5b2ec40525dfe0365f69c5d0e87ef540e
Deleted: sha256:0b4cc1e85da194d33b725e49437b56c81d66faaa45e14d05cb6ff568b1c7219c
Deleted: sha256:1d8bf60e57d8a3ed62c0c7f4ece246605613db183e96b73b100bc774c7205e59
Deleted: sha256:9ec45bfe5e914d00a0a9b128b530cf33a8adf1e03f3a6a6a964b250dcfb3c1f7
Deleted: sha256:0cc943f6307ba5b8921176595823b438137fa28ffa9cc53806852b2dc8d5efe2
Deleted: sha256:401d91328dfcf2c0ab29ab31c5c16bf313769be4ee0cce34b6401ff1d617f295
Deleted: sha256:6517a1398a166a78c44cd20bef60c2b36dc37615ab43a19632b455d761c24fef
Deleted: sha256:2c19d0903aabd00dac6b919434a69737e7f878648b3d2adbb6b441297e2dcad8
Deleted: sha256:d207d4399cef86bdab6f3097845ca3f269f1d2b82e958bc19839d937b91b6260
Deleted: sha256:77731f5626c2cc9b968445233c3d5210fd05017e00d3a4d169fe8a0881ead362
Deleted: sha256:bf0053cc96e04fd1db3c03872a3219a3851e440c30e4ca06827979d6c1870e9f
Deleted: sha256:b738dab3aad2730c71f0d2db2cb8c3f6f4e489b911104cd50ccb9ee94e7e9dbe
Deleted: sha256:75c40f0343bf8e0eeebc0338ed46731dd05fc683f2d68eadd09e90064f94bb41
Deleted: sha256:59b402951a25f49a242a1c9fc258ffb1fe8a60568c09cd16c638bd20128822f8
Deleted: sha256:1344afac1383761e73abc7bee8742c5b1249590fc3254a8a79685f66717c042c
Deleted: sha256:1b052f6e95be3af404a8d256321cc7eca26ebff1615ffa45e380b8a90a20521b
Deleted: sha256:0af8a95fb6a9c5295e8084d66f6562f703f5b10c6770cde5767d831e8aef3ee7
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:31f34f1f115161d46df461529111467d583290f8fbf8fa5ae83e47922d8e2063
  Associated tags:
 - 20230303-083205
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-083205].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:31f34f1f115161d46df461529111467d583290f8fbf8fa5ae83e47922d8e2063].
$ rm -rf /tmp/tmp.VK5B8hZGzK
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303082039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303082039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303082039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e3f9589e93144bb7550eac162c3f6c64927a1c8cd2347ef6e652e1eaef96d92f].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303082039
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303082039]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303082039] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:712043433cb613f942554bbee009ea30d648c0ac0f5734d843428d7423121cce].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1727829.
Stopping expansion service pid: 1727830.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 49s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1355

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1355/display/redirect>

Changes:


------------------------------------------
[...truncated 1019.45 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303022030",
            "environmentId": "TwVACRGXaSbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158"
      }
    ]
  },
  "name": "go-testxlang_partition-997",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/03 03:16:11 Submitted job: 2023-03-02_19_16_11-15818367307648058173
2023/03/03 03:16:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-02_19_16_11-15818367307648058173?project=apache-beam-testing
2023/03/03 03:16:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-02_19_16_11-15818367307648058173
2023/03/03 03:16:11 Job state: JOB_STATE_PENDING ...
2023/03/03 03:16:41 Job still running ...
2023/03/03 03:17:11 Job still running ...
2023/03/03 03:17:42 Job still running ...
2023/03/03 03:18:12 Job still running ...
2023/03/03 03:18:42 Job still running ...
2023/03/03 03:19:12 Job still running ...
2023/03/03 03:19:42 Job still running ...
2023/03/03 03:20:12 Job still running ...
2023/03/03 03:20:42 Job still running ...
2023/03/03 03:21:12 Job still running ...
2023/03/03 03:21:42 Job still running ...
2023/03/03 03:22:12 Job still running ...
2023/03/03 03:22:42 Job still running ...
2023/03/03 03:23:12 Job still running ...
2023/03/03 03:23:42 Job still running ...
2023/03/03 03:24:12 Job still running ...
2023/03/03 03:24:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-02_19_16_11-15818367307648058173 failed
--- FAIL: TestXLang_Partition (550.45s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3161.434s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677810754412544387
--- FAIL: TestBigQueryIO_BasicWriteRead (4.37s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41397 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@flgDeWaigv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@flgDeWaigv"}}  windowing_strategies:{key:"w0@flgDeWaigv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@flgDeWaigv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@flgDeWaigv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@flgDeWaigv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677810754412544387\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"flgDeWaigv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41397 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@flgDeWaigv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@flgDeWaigv"}}  windowing_strategies:{key:"w0@flgDeWaigv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@flgDeWaigv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@flgDeWaigv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@flgDeWaigv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677810754412544387\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"flgDeWaigv"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0000fb680})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0000fb680})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001690e0?, 0xc000138230?}, {0x1138176, 0x39}, {0xc00015a180?, 0xa9cba0?, 0x1?}, {0xc00048ec60, 0xf}, 0xc000559d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169080?, 0xc000138230?}, {0xc00051c300, 0x52}, {0x1?}, {0xc000559ea8, 0x2, 0x7f8099002d98?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ec60, 0xf}, {0xc00051c300, 0x52}, {0xeba5c0, 0xc0003f4160})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a9380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a9380, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.399s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.040s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:07c5bc1064c244536a0711f70848701e38123f5f58341995c7d0ce54debbdcb4
Deleted: sha256:3b444b6605515172caec3d9dd4aff47f4e78ba7d15fbd7a9c5280c631a2e450d
Deleted: sha256:885bf67acdd6c5cfcfe25bb4b65500fcff51f7f2b2ae6cf5f523f2cf7313c76e
Deleted: sha256:4df0a4120e34d036a14ebef22d704fc670984c13c5f94ebda7ce71a455489d17
Deleted: sha256:3bc76da46ae572441a8f9d78db09d21d170204222754abaf24e9238a5aa934ed
Deleted: sha256:f205d724ef6fcbb68487335fc05a63bcfdf6d5ed762bc97adf80c4eddd9e2fd9
Deleted: sha256:77ba31ff196b7d820387e844d1891031f8951f3ead05a5a2c1a009a6b5381f98
Deleted: sha256:69d20fb6ff92cac239bd64265bb3608cd9436a3000da4638af50f85e5d68be43
Deleted: sha256:3830ca208b7f529fbf8757b15d84475986fec53e72876c1d72412485827e071e
Deleted: sha256:b6657a6a48e6885ff89001d21213b5546a83879eac7c07663e3e30ab88784125
Deleted: sha256:9fd4bf77fad06ea038d0e2e8f8603502e3cf9e65ccc5e000d01e3f03dea1236b
Deleted: sha256:1820a72c6df045170fbf110ebfda1c08537e7ec63891faca301e663aa8e6efc6
Deleted: sha256:8244b070a6ef2e5c284a08e6a8c68e6f4db8484885fd5238dd96aa3282dc069a
Deleted: sha256:bb9593edc22e5f539a686b8e5518b8c53c08968789d0b765cbb415ebbbf2ea12
Deleted: sha256:2bfb32fee331f366e6e0883d73375734845bd314fa1d1ede1d8e3bb7af658449
Deleted: sha256:14f50afb1c544313fb3a69925c5f166f20d88a85322ec45d4551485d17e19c03
Deleted: sha256:707b8d31958503a795012a3e238ba010bf52c89d79b379f1d7f0da8c892db881
Deleted: sha256:edfeb889ab8c3f872c7c50a8be80084467b61ad9bf6dff09899ef0fc4a3137ba
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:07c5bc1064c244536a0711f70848701e38123f5f58341995c7d0ce54debbdcb4
  Associated tags:
 - 20230303-023158
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230303-023158].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:07c5bc1064c244536a0711f70848701e38123f5f58341995c7d0ce54debbdcb4].
$ rm -rf /tmp/tmp.wDGBRisD9U
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303022030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230303022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:aadf2e3cf46e09437b7eab3a9f74357e06eded96a37f3183423353d4350a19db].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303022030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303022030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230303022030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0c3f744a9d92c31c8f00b6561e31fa951ebd1209f01dceb883bbda880e9940b3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1522955.
Stopping expansion service pid: 1522956.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 8s
232 actionable tasks: 175 executed, 47 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1354

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1354/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302202035",
            "environmentId": "lyQAANQtZubeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355"
      }
    ]
  },
  "name": "go-testxlang_partition-758",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/02 21:19:41 Submitted job: 2023-03-02_13_19_36-161087941660354411
2023/03/02 21:19:41 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-02_13_19_36-161087941660354411?project=apache-beam-testing
2023/03/02 21:19:41 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-02_13_19_36-161087941660354411
2023/03/02 21:19:41 Job state: JOB_STATE_PENDING ...
2023/03/02 21:20:11 Job still running ...
2023/03/02 21:20:41 Job still running ...
2023/03/02 21:21:11 Job still running ...
2023/03/02 21:21:41 Job still running ...
2023/03/02 21:22:11 Job still running ...
2023/03/02 21:22:42 Job still running ...
2023/03/02 21:23:12 Job still running ...
2023/03/02 21:23:42 Job still running ...
2023/03/02 21:24:12 Job still running ...
2023/03/02 21:24:42 Job still running ...
2023/03/02 21:25:12 Job still running ...
2023/03/02 21:25:42 Job still running ...
2023/03/02 21:26:12 Job still running ...
2023/03/02 21:26:42 Job still running ...
2023/03/02 21:27:12 Job still running ...
2023/03/02 21:27:42 Job still running ...
2023/03/02 21:28:12 Job still running ...
2023/03/02 21:28:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-02_13_19_36-161087941660354411 failed
--- FAIL: TestXLang_Partition (586.42s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3279.122s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677789277799287559
--- FAIL: TestBigQueryIO_BasicWriteRead (4.86s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38643 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@puZxeiPtgZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@puZxeiPtgZ"}}  windowing_strategies:{key:"w0@puZxeiPtgZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@puZxeiPtgZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@puZxeiPtgZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@puZxeiPtgZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677789277799287559\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"puZxeiPtgZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38643 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@puZxeiPtgZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@puZxeiPtgZ"}}  windowing_strategies:{key:"w0@puZxeiPtgZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@puZxeiPtgZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@puZxeiPtgZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@puZxeiPtgZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677789277799287559\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"puZxeiPtgZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000031000})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000031000})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000660580?, 0xc00051a050?}, {0x1138176, 0x39}, {0xc0005ca000?, 0xa9cba0?, 0x1?}, {0xc000043b80, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000660520?, 0xc00051a050?}, {0xc00004c840, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043b80, 0xf}, {0xc00004c840, 0x52}, {0xeba5c0, 0xc0003f6108})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004829c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004829c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.898s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.041s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:96be88f547b5ab55228634e012952a82c503c4085e3a6d90bdb1dec16092848e
Deleted: sha256:77a7e0ffc70708dec85723fbabedd339a7d3ecb9cb3b4739cb5f41493b198d14
Deleted: sha256:c5689e943709b74aca95e7af83dd8d98a73d399df8ed2f8c4601ab127bb5f95a
Deleted: sha256:c821cb8a794e054bec5d6bb32cc02f46ec663a2e3f77cda70823a11dea014447
Deleted: sha256:5f97f10fd12dbf88558ff4a3174da6b89aefab66ad0587a2fd4e25aa904a18d3
Deleted: sha256:b66f305ab5a285b8e1b4e136d7ee333d51e04e6d9b922afa7fd8ccddb3fb637f
Deleted: sha256:46ab906c89e03ce114d8a901f627fc60346f0ff9a4a784f39dcacb01c2ef0b74
Deleted: sha256:8adcaf7e1e5844c0bb3721bcf24255314350d231725ceb5bc16d2353f9d8a559
Deleted: sha256:34025c18f0c728b7fd3e3ee6ab47b8e7b734c2ab51fb8855e898373ae37cfa4b
Deleted: sha256:3bc8f18b0b5525e162d6fa4ea9486e30f40249b3df1a44167d53495413ac8b3d
Deleted: sha256:27b42cc1d618d008ff28a4be6df69f84926e39c995f6637566653f2e2678e601
Deleted: sha256:c54d70d6901fd4d25bfef08f89ca8e62b394c6f1c2ad7a442f61c26fb98d2d74
Deleted: sha256:74dd087a44e2455427745d38ed203be391d7f6d1fa06ba9af21d71f4f2f9451c
Deleted: sha256:49fd9785efc1ea94567e0cef808c5501c983e275d08f15ab46d9e51803ed213a
Deleted: sha256:81be5b9cf9b1e62a63fa0fa12975f3208f682d881270ae6e50da15fe97b80bc9
Deleted: sha256:bd8f30127048575ae720c8734aa2bd431f6fd2855d4b99717164e28cbb09e690
Deleted: sha256:bf7d2d3f5d59dc7f41a5921e3b0d615e207001fa1db59838a9791028789f74df
Deleted: sha256:b3d37781451258ba0fa7503f6795629467df6f84fb8a47ed20f21a1597cd927d
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:96be88f547b5ab55228634e012952a82c503c4085e3a6d90bdb1dec16092848e
  Associated tags:
 - 20230302-203355
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-203355].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:96be88f547b5ab55228634e012952a82c503c4085e3a6d90bdb1dec16092848e].
$ rm -rf /tmp/tmp.3MqC1brRp3
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302202035
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302202035]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302202035] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0d14261279b0ea48f569f6764ac9401188686ba3153ff12a8af033a9cec17c33].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302202035
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302202035]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302202035] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:10a5fae8576acabc6255dbc1d9ee98ce5e97be2397e81fbe13b61253b0413663].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1220244.
Stopping expansion service pid: 1220245.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 7s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1353

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1353/display/redirect?page=changes>

Changes:

[noreply] Add timeout to unit tests causing SickBay PostCommit timeout (#25664)


------------------------------------------
[...truncated 1.05 MB...]
2023/03/02 16:10:21 Job still running ...
2023/03/02 16:10:51 Job still running ...
2023/03/02 16:11:21 Job still running ...
2023/03/02 16:11:51 Job still running ...
2023/03/02 16:12:21 Job still running ...
2023/03/02 16:12:51 Job still running ...
2023/03/02 16:13:21 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-02_08_04_19-7465287918083408167 failed
--- FAIL: TestXLang_Partition (582.13s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3242.431s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677770401299559026
--- FAIL: TestBigQueryIO_BasicWriteRead (7.78s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39209 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BHhUPCBGEH"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BHhUPCBGEH"}}  windowing_strategies:{key:"w0@BHhUPCBGEH"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BHhUPCBGEH"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BHhUPCBGEH"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BHhUPCBGEH"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677770401299559026\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BHhUPCBGEH"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39209 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BHhUPCBGEH"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BHhUPCBGEH"}}  windowing_strategies:{key:"w0@BHhUPCBGEH"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BHhUPCBGEH"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BHhUPCBGEH"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BHhUPCBGEH"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677770401299559026\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BHhUPCBGEH"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0000e88c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0000e88c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00011af60?, 0xc0004b02d0?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc0003f9a00, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00011af00?, 0xc0004b02d0?}, {0xc00004ccc0, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7fc1a83044a0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f9a00, 0xf}, {0xc00004ccc0, 0x52}, {0xeba5c0, 0xc0001c4d10})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	10.810s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.078s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-151856
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-151856
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cf189dd5d1c93231975ec7b54619ccc29a1f0c9b7975da7d2111e76851ceb920
Deleted: sha256:e2d342e3becb8ac613d7ad1d06e80b22eb107f17c3b454ea1ca07434ec628934
Deleted: sha256:1263b091c01e663f9c3c762505f778c3b34137a702d0323e7ffb5724f27cd522
Deleted: sha256:ab66fbdf19d92bfb87d8f78238a84918bf0c8c77e92f94930884a788b1b75070
Deleted: sha256:802965bf8b4abfdd31bdfa478b4b024aeccdfcefe78a40663f5484744fdcc52d
Deleted: sha256:bdd943ae8d8d9c4891be4474c49c6f1713c624850a0e0df2cd6358e5bcb9b27e
Deleted: sha256:3506f42d10c02eba28d9607d805f74ebc820ee112a66a06f45eaac35bdaf3e31
Deleted: sha256:b6723c33a9b2a4dbd81d388784ec1f4bae66350f7824dbf804780be3b78b4299
Deleted: sha256:cd189af0f44ec58721455469e975f95980e4c5558482195613f74b0b3a1925e7
Deleted: sha256:cc8d08db0f00a03c13ec96aae241d2b9597d9c9ada64d6228a8cf2605c1d8e36
Deleted: sha256:94b3010690442a9b8b479b8148d1e5d9ad33e10d8f55a8feafe9817a8664ff52
Deleted: sha256:3ed55f59a426514e7ebd1a9a522ccbec468a216a851b9dd971a1253f7a00a884
Deleted: sha256:43be72ba659809ffc6e8ab5df8abce4d2e8bb4587228fa4cd2da423e33d01e84
Deleted: sha256:2f8a3fbc4e64a09f830e99f68b1b0c920cde4272793037d5b0f0e5d1d72f0faf
Deleted: sha256:d8f980b269d7a5e9fdf65856e88a7fb51ad8a1e20bcbbc62db3dc581f29912cd
Deleted: sha256:fdc9b69826041199caa58ef64e228587b9a5d031b6f9b742fff81f982f56ae4e
Deleted: sha256:5fecd1a8088e7902e1fea2e98329be325078b241d84b26e7df6a200b3d16456b
Deleted: sha256:6dc6da384aeec99a0ae2b776fa8c8d19e60c3bc87d71d4fca4c965c8e810cce9
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-151856
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cf189dd5d1c93231975ec7b54619ccc29a1f0c9b7975da7d2111e76851ceb920
  Associated tags:
 - 20230302-151856
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-151856
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-151856].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cf189dd5d1c93231975ec7b54619ccc29a1f0c9b7975da7d2111e76851ceb920].
$ rm -rf /tmp/tmp.i73f9u214Y
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302150227
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302150227]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302150227] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:07028b37912f1b6ef71e0fdb867c282fbf94dbfe8a6a8f094805dfb3b46852cf].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302150227
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a
Deleted: sha256:5bd206c2f33ba1ec7ea12bfce80ee7141e0377997026bcb7d18d58feb4a8e176
Deleted: sha256:fddbcb1f54ae96a2ec86832b9c31664f519e628354da51301d63bf5874e04817
Deleted: sha256:d9300b8d41d79110ee12c8cbda3e0a14dfb817cbea668e08d8f1e91c4feb6157
Deleted: sha256:337336c7a9c8123bc513a71d17cfda079c2ccf40ac7fe3c604060ecf5d2c1e88
Deleted: sha256:2755326d3edd737706ef1e9ac4af90dccf530c3b74cb024400362ec0397991c4
Deleted: sha256:62d8872b4decd6ac20feb9f1df75edf76e897c7956ca482763c9572d73610db1
Deleted: sha256:e8aa7ffc1172edce48f7719b0b012bdf1e5c61baf1a9445707ead64e28f6f144
Deleted: sha256:d97a864b94e955565330239cad6cc94d4e67c467600c3498f4b09cf687bacddc
Deleted: sha256:9254691a2a42cfc7fc9f4d2029bf06775bdaed0240699eb528d29fa287ab1ff7
Deleted: sha256:32df5eeac0e736f8c19d6bf6d79e13847fda56bb392acfc9e062a534597f393f
Deleted: sha256:02ca8cee0bc9c204f41a84af162e2b64bfca0ae7ffd826f42bea6be3cc8fb389
Deleted: sha256:65c6ec14ba5d126dcbf8b392bf6c2d17e5a626990f126c51bb86d7c042a81d04
Deleted: sha256:edf157a4b4e9dc58211ce2287a3ebdeb9c40e989cb9f68f6e2ed4c0488b64af3
Deleted: sha256:072a35e6db8a80db1e0f8073294041736cc8d860834e9daa6ad4805f244bebc8
Deleted: sha256:a67a62db92a7572c9e1d902aaec32cf65d7d2bf0af56c6326493b45254b71adc
Deleted: sha256:abfed4446840308fef03f3d3b1344dbf16516c7e756129abd6d927957f452de9
Deleted: sha256:2e2fe2c4f9184e3b37dc94808b553aee73ed79cd08f42339db6cb5dde9385aef
Deleted: sha256:2c37b11aba671e22e8ba4493df141ce555c69a7956f0beeb022b185653b40810
Deleted: sha256:d2868bb91ec50dfeb5dac7af3deb7807db6a47754fe71791f078c0858d9424f7
Deleted: sha256:857907cfaed38c77460b1f69d215e5d11345bfe8e482e523d09a5b15d1d68a9f
Deleted: sha256:541fd3820232e65507bc1f995851d22fb60f09d990ef90481e3d055475e5f88a
Deleted: sha256:b47eeb95d026d10ad2c4c40371d733e25f0da2324a373f923e4108c4fdb633dc
Deleted: sha256:d79631be898031087586d4c28ccb62ceedc31ef6a3026e4f3e803e63517c4953
Deleted: sha256:11c0c35402da4bd6508de6c90ac5ec97562ff85f2b3534937ad0e7d9bd2defd5
Deleted: sha256:7346ec64c25f9ce92327c1de9d00866edfdc8008d9e97c24da55d98768e930a0
Deleted: sha256:e9453d34e08f1b342f28be048d44e110e602dbcd2fd70cb0404b2745272c5e29
Deleted: sha256:226df37422a9b0a2c30854971c6ee1ef5f985c883146af2f33800a16a847eac0
Deleted: sha256:6b4ff6fed44392cf613e499bbc2474ccdc95f9f2097a7eb60329df004555717b
Deleted: sha256:d3cfa91d1f81d82dc0eea32d13499bc6ae3c87d043ec414e108eaf75dfd4cf85
Deleted: sha256:265ce30f8b9601d72e3ec1bd48d7f41f841aeb87db27ae1a78486197442c0160
Deleted: sha256:d68058d98be181b5c8cc5225c4c795e6ff44b864d7717443429160a1f1afce12
Deleted: sha256:4e847ac28f7329530bfd3c4e5ac3ae82187259d2383ba25638c6d4528a344aa1
Deleted: sha256:73287c0f77467cbd959d77dfe7ccbd09155a075028f2b64571f6c646e9edc13e
Deleted: sha256:594c522263a77b4cddbf3b207b479099383d9fa056712bf9ac84a3121230b1b2
Deleted: sha256:ae94c9673218b242a51a2738d863749fc621b97a4c773af0764c3a1ffe2ea877
Deleted: sha256:491d9e83104893bf436c996905842dddae85a1501aadfbd8b14447796aef47df
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302150227]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302150227] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a4bbb9eeb6c14f8b2f4af9cfe2077db6ce07a9184182aca5b96baa965911f7a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2554794.
Stopping expansion service pid: 2554795.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 12m 18s
232 actionable tasks: 157 executed, 63 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1352

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1352/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-083140",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302082031",
            "environmentId": "IwRLAxkkcdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-083140"
      }
    ]
  },
  "name": "go-testxlang_partition-162",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/02 09:17:12 Submitted job: 2023-03-02_01_17_12-14926720014969018099
2023/03/02 09:17:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-02_01_17_12-14926720014969018099?project=apache-beam-testing
2023/03/02 09:17:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-02_01_17_12-14926720014969018099
2023/03/02 09:17:13 Job state: JOB_STATE_PENDING ...
2023/03/02 09:17:43 Job still running ...
2023/03/02 09:18:13 Job still running ...
2023/03/02 09:18:43 Job still running ...
2023/03/02 09:19:13 Job still running ...
2023/03/02 09:19:43 Job still running ...
2023/03/02 09:20:13 Job still running ...
2023/03/02 09:20:43 Job still running ...
2023/03/02 09:21:13 Job still running ...
2023/03/02 09:21:44 Job still running ...
2023/03/02 09:22:15 Job still running ...
2023/03/02 09:22:45 Job still running ...
2023/03/02 09:23:16 Job still running ...
2023/03/02 09:23:46 Job still running ...
2023/03/02 09:24:16 Job still running ...
2023/03/02 09:24:46 Job still running ...
2023/03/02 09:25:16 Job still running ...
2023/03/02 09:25:47 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-02_01_17_12-14926720014969018099 failed
--- FAIL: TestXLang_Partition (553.79s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3245.454s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677745934915872614
--- FAIL: TestBigQueryIO_BasicWriteRead (4.23s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44511 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@HBqMCJjsbp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@HBqMCJjsbp"}}  windowing_strategies:{key:"w0@HBqMCJjsbp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@HBqMCJjsbp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@HBqMCJjsbp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@HBqMCJjsbp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677745934915872614\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"HBqMCJjsbp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44511 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@HBqMCJjsbp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@HBqMCJjsbp"}}  windowing_strategies:{key:"w0@HBqMCJjsbp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@HBqMCJjsbp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@HBqMCJjsbp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@HBqMCJjsbp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677745934915872614\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"HBqMCJjsbp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 22 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00048f9c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00048f9c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7660?, 0xc0004a9630?}, {0x1138176, 0x39}, {0xc00017c0c0?, 0xa9cba0?, 0x1?}, {0xc0003fae10, 0xf}, 0xc0004fdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7600?, 0xc0004a9630?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc0004fdea8, 0x2, 0x7fcfe05c9548?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fae10, 0xf}, {0xc00004ca80, 0x52}, {0xeba5c0, 0xc0000223b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.265s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.030s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bd36c26d04fe4a1d26e59c2b38c2d9b0a6d526f5c800b76ee62e49922d59b459
  Associated tags:
 - 20230302-083140
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-083140
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-083140].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bd36c26d04fe4a1d26e59c2b38c2d9b0a6d526f5c800b76ee62e49922d59b459].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302082031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1af3a40fc496136384d0c33e5c9170360dba531231ca1f08325e00f4fbc7350]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302082031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1af3a40fc496136384d0c33e5c9170360dba531231ca1f08325e00f4fbc7350])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1af3a40fc496136384d0c33e5c9170360dba531231ca1f08325e00f4fbc7350
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d1af3a40fc496136384d0c33e5c9170360dba531231ca1f08325e00f4fbc7350].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302082031]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f35b4e2dd747abab1c420dfcb63b017b39820cef660e0a01ac88dd91c10c91e1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302082031] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f35b4e2dd747abab1c420dfcb63b017b39820cef660e0a01ac88dd91c10c91e1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f35b4e2dd747abab1c420dfcb63b017b39820cef660e0a01ac88dd91c10c91e1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f35b4e2dd747abab1c420dfcb63b017b39820cef660e0a01ac88dd91c10c91e1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 11s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1351

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1351/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302022032",
            "environmentId": "TMIkJwXpZdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153"
      }
    ]
  },
  "name": "go-testxlang_partition-27",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/02 03:16:28 Submitted job: 2023-03-01_19_16_27-16137304478769729936
2023/03/02 03:16:28 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-01_19_16_27-16137304478769729936?project=apache-beam-testing
2023/03/02 03:16:28 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-01_19_16_27-16137304478769729936
2023/03/02 03:16:28 Job state: JOB_STATE_PENDING ...
2023/03/02 03:16:58 Job still running ...
2023/03/02 03:17:28 Job still running ...
2023/03/02 03:17:58 Job still running ...
2023/03/02 03:18:28 Job still running ...
2023/03/02 03:18:58 Job still running ...
2023/03/02 03:19:28 Job still running ...
2023/03/02 03:19:58 Job still running ...
2023/03/02 03:20:28 Job still running ...
2023/03/02 03:20:58 Job still running ...
2023/03/02 03:21:28 Job still running ...
2023/03/02 03:21:58 Job still running ...
2023/03/02 03:22:28 Job still running ...
2023/03/02 03:22:58 Job still running ...
2023/03/02 03:23:28 Job still running ...
2023/03/02 03:23:59 Job still running ...
2023/03/02 03:24:29 Job still running ...
2023/03/02 03:24:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-01_19_16_27-16137304478769729936 failed
--- FAIL: TestXLang_Partition (551.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3178.763s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677724359055653473
--- FAIL: TestBigQueryIO_BasicWriteRead (5.31s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40567 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@EpktaEWNKw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@EpktaEWNKw"}}  windowing_strategies:{key:"w0@EpktaEWNKw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@EpktaEWNKw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@EpktaEWNKw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@EpktaEWNKw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677724359055653473\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"EpktaEWNKw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40567 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@EpktaEWNKw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@EpktaEWNKw"}}  windowing_strategies:{key:"w0@EpktaEWNKw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@EpktaEWNKw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@EpktaEWNKw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@EpktaEWNKw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677724359055653473\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"EpktaEWNKw"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000478540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000478540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000594980?, 0xc000499680?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc000043c20, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000594920?, 0xc000499680?}, {0xc0005a4300, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7f58c0673a28?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043c20, 0xf}, {0xc0005a4300, 0x52}, {0xeba5c0, 0xc0005f9010})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ab1e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ab1e0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.343s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.031s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.038s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5d5e65b1a3e6bcee66171a0ab0ab9d269eaa179150e2bdf9f04a147699fc063f
Deleted: sha256:36ad10aad2a46afcb2a177356860fb72ad73f80a072542e69415df935736ce1f
Deleted: sha256:841504cee9426d25e9e3d3d693de136c11ba6d9ce6fdab12b7999f7fd82e0d56
Deleted: sha256:f4f71f9c5b9cd72b812452feb4be2612a002c9c5aec304608d54bacf571089d8
Deleted: sha256:384993faa6bd41ec594a418f03dc006a6fb5d9969f4222ff4c9932debbd6f82c
Deleted: sha256:b10bb6bf082143475f6c10c2bc3db0808eb155e5bed0744f758a34f8d8cddb2e
Deleted: sha256:eaf2d6629178fb82959648f82d1d13da0dd60d775b88e85e912e13b6de4ac08d
Deleted: sha256:e3ad01133b5136c8939cb1cf2a61a3b6eb105b995b375a3cdcd797e473fe561b
Deleted: sha256:14eff13dc058b9a695fa9b2c67487f6b2ae13af7445c091a57ef738249a9bee9
Deleted: sha256:f82208a4a9710fccaf692b7b3ba4e3159551028c8cd493034bfe8f545d7747ef
Deleted: sha256:bc06e843157faa1dfdeb05c52df8962f41ec5d5f737d7e1d18247bf159ca686f
Deleted: sha256:941dadc17374de09966cc92338b2ac913ff7cf189645d209e052de1742d11852
Deleted: sha256:6ff5c1a90c878c1c521c7169d4ab6c3ee41e11ee3e6a7d3f58102606ccb05af2
Deleted: sha256:0c54564a25b5a1f10eaf8cf218190f5fe43f75a2e8de8f4cb3aa3774247b6c16
Deleted: sha256:d3ba15b032554ee137b3c6f639a76e385749cda5e63dc5beed0d2808b3a7715b
Deleted: sha256:69682a176fe8592e85887527c60f8ebe62c5fe9b07853e1d6441035d1a7a324c
Deleted: sha256:cf75189a8439455f99e5b321b915a6f2d67d5eb6b405128a4d7e07f64befcc17
Deleted: sha256:191cbb2546a1c2c63a081b2846131cbd72ba10154f2d5a12b9538273851fbf5f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5d5e65b1a3e6bcee66171a0ab0ab9d269eaa179150e2bdf9f04a147699fc063f
  Associated tags:
 - 20230302-023153
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230302-023153].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5d5e65b1a3e6bcee66171a0ab0ab9d269eaa179150e2bdf9f04a147699fc063f].
$ rm -rf /tmp/tmp.fKSLptryw4
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302022032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302022032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230302022032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f60559a16cb402d5cf7f0636e7524a21d63b5951a3ac274f8198d8378c77b74].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302022032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302022032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230302022032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:13f3c6fa2170fa12e74b36f40b5cb16784e2b37cddfc4f71e0380b5f86c9d2cd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2940214.
Stopping expansion service pid: 2940215.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 22s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1350

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1350/display/redirect>

Changes:


------------------------------------------
[...truncated 1012.38 KB...]
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0003289a0?, 0xc000618e10?}, {0xf10318, 0x24}, {0x0?, 0x1075bf8?, 0xd29ec0?}, {0x7ffdb6c18461, 0xf}, 0xc000759c60, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/examples/xlang.Partition({0xc000328900?, 0xc000618e10?}, {0x7ffdb6c18461, 0xf}, {0x1645b00?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/examples/xlang/transforms.go>:106 +0x354
github.com/apache/beam/sdks/v2/go/test/integration/xlang.TestXLang_Partition(0xc0003da4e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/xlang/xlang_test.go>:256 +0x19e
testing.tRunner(0xc0003da4e0, 0xf551b8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	2707.802s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677703333365766306
--- FAIL: TestBigQueryIO_BasicWriteRead (6.30s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35497 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@kLXIvyjdfL"  is_bounded:BOUNDED  windowing_strategy_id:"w0@kLXIvyjdfL"}}  windowing_strategies:{key:"w0@kLXIvyjdfL"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@kLXIvyjdfL"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@kLXIvyjdfL"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@kLXIvyjdfL"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677703333365766306\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"kLXIvyjdfL"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35497 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@kLXIvyjdfL"  is_bounded:BOUNDED  windowing_strategy_id:"w0@kLXIvyjdfL"}}  windowing_strategies:{key:"w0@kLXIvyjdfL"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@kLXIvyjdfL"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@kLXIvyjdfL"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@kLXIvyjdfL"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677703333365766306\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"kLXIvyjdfL"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000126b00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000126b00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00058eec0?, 0xc0005a7630?}, {0x1138176, 0x39}, {0xc0000f00c0?, 0xa9cba0?, 0x1?}, {0xc000586c80, 0xf}, 0xc0005fbd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00058ee60?, 0xc0005a7630?}, {0xc00059e3c0, 0x52}, {0x1?}, {0xc0005fbea8, 0x2, 0x7f8a7811db50?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000586c80, 0xf}, {0xc00059e3c0, 0x52}, {0xeba5c0, 0xc000587f90})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102d00, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.331s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-204115
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-204115
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4c38fe811444b8810dbae37f2a3d8edc3dec362f2b1689b59b18dc22c6c8ec1
Deleted: sha256:fadfcdd10054570fee3db5096c4e6d8db46c403aedb088c4b4f1c2feb796c3f6
Deleted: sha256:f95a790a780810ea9e6243647f0064f4fcf960c91a27e6954c6883f75e4e8fed
Deleted: sha256:b0f4da8096c24077235de0ddc724bf22fa1053028d8a792fa4a78a724f86ae3d
Deleted: sha256:2bc6eeb5e5436424f2dbad59dcffb84a2658376f39b24e8a35f7ce748a6f8905
Deleted: sha256:2a4612af85e2296e565e7c1be78c813f3e405e8ce54a1c99805aab6a60406e5d
Deleted: sha256:bdf64adbe4284d057321ea443b43ab2d171be866c1ab62699db6ee03bdb2101f
Deleted: sha256:487024cac59f76aaae119310c7961d671ee59e7aa7e789cfc5b106dacfa6f567
Deleted: sha256:dff32dc410bda265a7e63742efef0039f4eed461ee9d40bf599c989b06759269
Deleted: sha256:4828c11930cec577a8f37a5e2b936670f6aebfe4392bb0c77d0843ab55789d5c
Deleted: sha256:b7e2939e6092ddfcef46f29c9b10d840fc00bdcba4c4af04c3f730e1901dcce6
Deleted: sha256:82d3089132fe3bf97e2517f6916093b69906d45104ef126c753f81716af9c6c9
Deleted: sha256:5cf374b17927cdc8eac4f1b04284e1a4c5d5e9b372d10d21caf2ca58ced394f3
Deleted: sha256:49633fab4c64a80bc803475d9f1a711bbe2a6bf04ec3f00e684bdfb1b925c2ee
Deleted: sha256:c63a9251bb3296ffc8c9a93994f3d9993071cb457a67f27f6fef577b1e620de3
Deleted: sha256:56c7452c372f3dac707a99f030e9bf5f2833596a604795d97efde81bea4331ea
Deleted: sha256:d81df67d978768016631dd1e522682df13e28c16d6fdfd30e32f7135032ebf9b
Deleted: sha256:1b76bfa6ff3234b03a8ac58ad97fe064e8b354759b0934fde529cd1da98f60e2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-204115
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4c38fe811444b8810dbae37f2a3d8edc3dec362f2b1689b59b18dc22c6c8ec1
  Associated tags:
 - 20230301-204115
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-204115
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-204115].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4c38fe811444b8810dbae37f2a3d8edc3dec362f2b1689b59b18dc22c6c8ec1].
$ rm -rf /tmp/tmp.d83v5zHwiw
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b1e8afa63b1ff2fc7bc6d134de66047f32b791d3ab0ebff69694183924a08b91].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301202040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0
Deleted: sha256:88f6729f0305898967c1de3108ef9eee83286b2273b3c8df8e31c95aa066d113
Deleted: sha256:3e882f6465c2a41298bafd5a895b1a4ca3f458558856bb48332bf4c81e0a8ec6
Deleted: sha256:1a26d3b8099122b9aecd57c97ea175613d02533181e0543c928a805135dbbadf
Deleted: sha256:c07687d9e381b3fb779f405dcc3e527e26f8196fc1e4806885883aabec1e9745
Deleted: sha256:7d9b8011de525e2439d6c0b51b55cc41ce362fb726f01c1f91ffa451d6998ad9
Deleted: sha256:a950645c1c9b020bd5f94165a949994664cc0a8d07bb119065aaa3ca50cb77e1
Deleted: sha256:5587938875b668ceb92e0f032f4eefa9a1e90d9aa70a19292fb099df3fb611c4
Deleted: sha256:e3c7a961920487cbcb1f07753e400b8325b737342a766ed07375031e0ccff864
Deleted: sha256:a25376cfd3c51095b1ffe25a7de72153273bfaa4b18eb19f4349fbb2e7d7ed68
Deleted: sha256:71e2ceefe1cf9223148b461e195d8fabbb366e14a699eb2896bfa6efc4e3f118
Deleted: sha256:5fa6e0e0d47c44a6acb2d385c9bbc6b08cb7a7f4606b6bf149b73f125e2cd9a4
Deleted: sha256:4a446e5f96cdadeb6c558c5772db58cd0533881fda7ae31ac9c9688351b94817
Deleted: sha256:1b612646ddeb5815cba68e8e1d47071703f59f14b4ee5708e66a510c45207190
Deleted: sha256:f00d460b54fa41ca607ea68c033ae54f38ab95735418446578edb7007950be1c
Deleted: sha256:86f590211eb6ffb56497fd2c18b5e40579acb2462a7e95ff9120b5702e5f41f3
Deleted: sha256:c37886d0e9bc0f25c12b3047499e7b87d3710fe3ba5a440db3eb2107db4d1a66
Deleted: sha256:dad21478378739e1745270dd1bf948a3981eb660516022a18c52a1582120d41f
Deleted: sha256:0840de05cb4c9e0585a778ff1cdf33818f7012f5381b3fba10a2c3267426d721
Deleted: sha256:51e0c4fa3cfc933171e2a1ddba6b21b59d8a8af890c837b751ec180918cc0721
Deleted: sha256:dc1f3c4e50e57afe646ffcc7512f0bfd31882f5309d0877d01377ba951a0980d
Deleted: sha256:4421b1ebad1c5f7d8a5cb5bf92bd35f8c48f0a61f0927137aefd057571bfa66f
Deleted: sha256:5eef37fbd7c4fc9cdb5f7043f77ece81d8e002ee274ce28c6d48d9cc2da336ea
Deleted: sha256:bbb7063dd3bd23319b2c3107575a90615766aeb744999645b408bbc49825647c
Deleted: sha256:ae47a873306de6a41648ffde7228d31023a72e1b59cedd786c1c684cd70a921d
Deleted: sha256:b0881ab8139f94cb2a434dfb0bff03902c3762b3dc6c70782b0bc92f8a1b4248
Deleted: sha256:c8c61ed7c5313d111813257050a741d8cbe3b6249fe285aa6d8a06383194257b
Deleted: sha256:56475901a33084db763e7fb39461d1727a3e9c030cd0575e4578c3ce8ae0dd83
Deleted: sha256:929345cc5063390b4f621c9e6fbbefd0ac03833e8db648c56f87762ab0572b8f
Deleted: sha256:5b0672f09463d6c582fdca8397a61e2bff7cdacb39aa482c0cb22474580f1968
Deleted: sha256:6ee269bae98441085d35042787af43f68a9613fc76b254f16ac5858e4b638d66
Deleted: sha256:974386e7fddc3019166ba6c204157355bd93f6e1a92f980fd32ee8c00e54d2b3
Deleted: sha256:433b9ae97d0e26f31a427794369ee31f6c1197b597bdf7acd225d446a10e6efa
Deleted: sha256:1b667f7361252f5492dbd982e82257bec8a46872785f676bf61f7710d35df3a9
Deleted: sha256:0d38e8e597a7943bc15db563830edde56b51dcd86440acbec2c62beb3f5a6d62
Deleted: sha256:13066ce294a6cc96f2e1007f9daec56dce313664032744cb83d7e74ec457928d
Deleted: sha256:f6c716a4e65eeab5f0bf1f366585fe33b77e9fe01592b68498eca6847d8cd556
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301202040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301202040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:43f918e074772669a109bd368479e1da03277d2a8e802be5b28bf99d256550a0].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1550606.
Stopping expansion service pid: 1550607.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 9s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1349

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1349/display/redirect?page=changes>

Changes:

[noreply] Fix flaky load_test.go/TestSample test (#25673)


------------------------------------------
[...truncated 1.02 MB...]
2023/03/01 16:00:11 Job still running ...
2023/03/01 16:00:41 Job still running ...
2023/03/01 16:01:11 Job still running ...
2023/03/01 16:01:41 Job still running ...
2023/03/01 16:02:11 Job still running ...
2023/03/01 16:02:41 Job still running ...
2023/03/01 16:03:11 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-01_07_54_39-572837952989327556 failed
--- FAIL: TestXLang_Partition (551.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3215.926s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677683414459068049
--- FAIL: TestBigQueryIO_BasicWriteRead (5.72s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35075 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@QSEARrlWxZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@QSEARrlWxZ"}}  windowing_strategies:{key:"w0@QSEARrlWxZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@QSEARrlWxZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@QSEARrlWxZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@QSEARrlWxZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677683414459068049\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"QSEARrlWxZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35075 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@QSEARrlWxZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@QSEARrlWxZ"}}  windowing_strategies:{key:"w0@QSEARrlWxZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@QSEARrlWxZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@QSEARrlWxZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@QSEARrlWxZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677683414459068049\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"QSEARrlWxZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000026580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000026580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6ce0?, 0xc0001399a0?}, {0x1138176, 0x39}, {0xc00015a0c0?, 0xa9cba0?, 0x1?}, {0xc0003f6d50, 0xf}, 0xc00024bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6c80?, 0xc0001399a0?}, {0xc00004c540, 0x52}, {0x1?}, {0xc00024bea8, 0x2, 0x7efe11d23b58?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d50, 0xf}, {0xc00004c540, 0x52}, {0xeba5c0, 0xc0002e0060})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cc820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cc820, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.756s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-150928
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-150928
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:713250c917f08fea40fac880bd88b1ff2068837d0fffcbd893b3106f8cfe0529
Deleted: sha256:53e1fce7994a522ae271f0f8c00ce15f5684195e36cc299a2bb283e9ad5fce2b
Deleted: sha256:0ddb5de6690249754f06dc5e7d3ac47d5d71f2fde16bbbe04588bd5a181aff81
Deleted: sha256:ac9e2e3f16cfb4ec6964d10a223c194b9afe70fb2ba00dd74765366732e64008
Deleted: sha256:fbc0e5ddfb67367e9854c135a1fb305aad496feae0ba54cfb6cbe288803082c3
Deleted: sha256:e928cfbe87e1897f98b0cf43f7afcd8e19598e0a1f8f429f866e2f9af6908a75
Deleted: sha256:f71f82c5de897eba1af40f81798e7f71a43d29d9377b48a4f0ef45907d20e5d2
Deleted: sha256:7a06b4f5b6f665e89e336acbcbf7b2a35a237c7776dc0570152e15e7abc54335
Deleted: sha256:5852a9cd26d14a889d9591c289e4b7a4c7e1407c72e50c2dd0f7fac6ddfa639c
Deleted: sha256:58e69b4aae0acc2db540ea95deaedc6f18581e6f97647bea2c9512dd49b0d0e8
Deleted: sha256:e48aa0364620af5ddef9e5c6cfb1c4db552ba2c6d71d5e42858ebc74543f3171
Deleted: sha256:4808e38ba0e25a4e9811e857ba3223b5d413643d321c52028f38bf827850d2d7
Deleted: sha256:9a82770a350ae606d5c6ffca82501b07f52183a34de2eb85e0c1e0ceb92409e6
Deleted: sha256:5ea994e9a14c640e4a5415095d9f80a985e595ee64e5bee8c8abed9d0210988e
Deleted: sha256:609a76dd4701e32f9c4281291c568838ceaed4d4fcb1a090bb314c0a5f8ccb64
Deleted: sha256:beec066db0524826d8149d9a815162b714ae21e972c2d21c7323b03d6f5ac846
Deleted: sha256:793b5ec1fea48591b2d10843bdbd28082aa3e3ada0fa2f1c34cbc2525100e8c1
Deleted: sha256:826f97b3a182aefc407636f3554b2ffeb394bb5ffcd3e42983f428dec169c3d8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-150928
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:713250c917f08fea40fac880bd88b1ff2068837d0fffcbd893b3106f8cfe0529
  Associated tags:
 - 20230301-150928
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-150928
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-150928].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:713250c917f08fea40fac880bd88b1ff2068837d0fffcbd893b3106f8cfe0529].
$ rm -rf /tmp/tmp.cHmI4cyJbI
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301145744
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301145744]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301145744] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c1e63cdf647b0baddfef2ffefa01f308e4d2724a0185f262a54b5e271a34861c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301145744
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53
Deleted: sha256:cc48477ad5e96e15a61a910109cab5d3ee8ff0a8bdf086900cf08ea24bc068f5
Deleted: sha256:0f12ab2da6c5a8caea0b6917f573462a2961119bcc1167549c21ff932578ca4f
Deleted: sha256:275904081b66a347ed2a233c14c0a9f611c768613301c4ef43e9958761e763c9
Deleted: sha256:9643dacc75dc10957c02377a3f53086413ddd9cf539490d95b7247b92d1bdc1a
Deleted: sha256:55faa7fb2f012ff3fd950d4944f7a8e4e6ea21d8dbdeeacbd197d81c21f2b7a0
Deleted: sha256:6cfeb8dc4185e0abf1c65eff1f978dfe09a39cadf7b0c3db5b3e55e18fd011ff
Deleted: sha256:aba355391bbf1b0ad197fb79870d5a3c80b8b0d33139b531f9d2903127110d99
Deleted: sha256:afc46296091446b543a85b4da5b6b053f919c4f6306f9f2af72e765c00a56d6e
Deleted: sha256:6613ea8eb8e0152688b0a63ccee844b62b0fe13284fbc00bc46cf58dc99d2b0b
Deleted: sha256:cb17deeafd49701fd170295cfe07d2faff6f2f02ee3c54b8429f4a93a73221e4
Deleted: sha256:8560e8c9d422c3db835e8921d8fa9f2b4241424e43ce8a15fa9777d97aac7913
Deleted: sha256:68351447a95ee8e3842d13359d70e06f0211df8de3ce53ac3084a343e0362325
Deleted: sha256:ea7f10e868b7fe79cbe57f36f0731c25ee22a54293505f8ba18f3388f459e977
Deleted: sha256:c83ca4ee3ca2e990930817cb4cab2210c16c62855be152ed7c1e1f42755521d5
Deleted: sha256:519c27236243784b245717f253610bb783ad97f3751d86940690e31f400af53b
Deleted: sha256:d0dcf60646aa039ed3a0840701259f75b85ccfdc7b66fc795476b7de75b60feb
Deleted: sha256:4905abaebe9fd09b5141115a9e61af11a2562971ec9e1546cc869f75d1bf1124
Deleted: sha256:ee0b76a02a17eecbecbbb9133918e152cb65c0fafd43260a75c5d36f86c5e9dc
Deleted: sha256:0e35244395a57c070ef471e33202a9b9cf5fca441bb88d3c215a665a0a208788
Deleted: sha256:af9b71408ad3de220fbd0e7672a2d447a759e3563b07b4b03651419460bac931
Deleted: sha256:803a4b36e3d081bcbec4b4c85e0f7ce56f8e6d78707a473b730da9e78c092ac6
Deleted: sha256:a528ae7174e46ea72d59395f95e14c8717346c650366d05c56e45fcd37f6b0a1
Deleted: sha256:bff1cec5dfb9bfa6f6a11d8700ec5a27a65737184dd628b7a84eee040ea6c637
Deleted: sha256:545978e735747ea0fd2331a9a7c3c22398603ebe11b5d9c4ebc31540df551b9e
Deleted: sha256:f9c51d3f1d3b3d39c1879d3d94a5334c7467b45b3511ac35ec7e87a4c810e904
Deleted: sha256:6ba41f53e560183595fca38a4e14b295d2486859a6e1995ddf4476cb90413aea
Deleted: sha256:7478c8e5af003fc7f229b13e2c919196496128682429b806d7e37bc7f7f7127b
Deleted: sha256:8264871834caf48b378d7e375e10a72f6b243689e62c241920527c7efb228981
Deleted: sha256:d08dd98b9372075933505b8b6a1ea4fcc53c0f569ce1cdd6e14be97e5189987e
Deleted: sha256:46389062b191b5a64999043206d993fd6c506e2427326c2a2bb427378577e507
Deleted: sha256:a92fc713bcce6f18f74252e5d445bb99d75e2f4879f43fd81dd17192c4edda96
Deleted: sha256:6c9c7fb71f3cf8de386a3ff58a28d5bd1e79ec51371d481adde3c638cddf3188
Deleted: sha256:bcca01abf6bb3479ef821c01df788c3c413d221eeb0c069d977df1362f1abc49
Deleted: sha256:a47e29f139462a159a58206da6cea26107f6d72247ca0aaf61597e2b85b3f810
Deleted: sha256:8d1dcaba3e01bbdb0743d54522f670a7bcf9498d24fc10accca9407c9002c1e2
Deleted: sha256:032bfc320cb31bdbd601ed54897428ade4a92912f0d4bd0f2c34ba1881794456
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301145744]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301145744] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:af1a405d8a217d8fd5d75dffe545ab24f41fbb63194f91ab820fb09920e0cf53].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 956407.
Stopping expansion service pid: 956408.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 33s
232 actionable tasks: 162 executed, 58 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1348

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1348/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301082028",
            "environmentId": "wmiuWqcOkxbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153"
      }
    ]
  },
  "name": "go-testxlang_partition-438",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/01 09:16:52 Submitted job: 2023-03-01_01_16_52-836506393808940002
2023/03/01 09:16:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-03-01_01_16_52-836506393808940002?project=apache-beam-testing
2023/03/01 09:16:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-03-01_01_16_52-836506393808940002
2023/03/01 09:16:52 Job state: JOB_STATE_PENDING ...
2023/03/01 09:17:23 Job still running ...
2023/03/01 09:17:53 Job still running ...
2023/03/01 09:18:23 Job still running ...
2023/03/01 09:18:53 Job still running ...
2023/03/01 09:19:23 Job still running ...
2023/03/01 09:19:53 Job still running ...
2023/03/01 09:20:23 Job still running ...
2023/03/01 09:20:53 Job still running ...
2023/03/01 09:21:23 Job still running ...
2023/03/01 09:21:53 Job still running ...
2023/03/01 09:22:23 Job still running ...
2023/03/01 09:22:53 Job still running ...
2023/03/01 09:23:23 Job still running ...
2023/03/01 09:23:53 Job still running ...
2023/03/01 09:24:23 Job still running ...
2023/03/01 09:24:53 Job still running ...
2023/03/01 09:25:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-03-01_01_16_52-836506393808940002 failed
--- FAIL: TestXLang_Partition (550.54s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3208.225s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677659548973542183
--- FAIL: TestBigQueryIO_BasicWriteRead (4.34s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36959 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@KWZkhSujGV"  is_bounded:BOUNDED  windowing_strategy_id:"w0@KWZkhSujGV"}}  windowing_strategies:{key:"w0@KWZkhSujGV"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@KWZkhSujGV"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@KWZkhSujGV"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@KWZkhSujGV"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677659548973542183\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"KWZkhSujGV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36959 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@KWZkhSujGV"  is_bounded:BOUNDED  windowing_strategy_id:"w0@KWZkhSujGV"}}  windowing_strategies:{key:"w0@KWZkhSujGV"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@KWZkhSujGV"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@KWZkhSujGV"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@KWZkhSujGV"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677659548973542183\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"KWZkhSujGV"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0000b0cc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0000b0cc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e660?, 0xc0000bc2d0?}, {0x1138176, 0x39}, {0xc0005c0180?, 0xa9cba0?, 0x1?}, {0xc0003faeb0, 0xf}, 0xc0006e7d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e600?, 0xc0000bc2d0?}, {0xc0005be420, 0x52}, {0x1?}, {0xc0006e7ea8, 0x2, 0x7f12dca68aa8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003faeb0, 0xf}, {0xc0005be420, 0x52}, {0xeba5c0, 0xc000128190})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.368s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:514023ae9b2f4e5b9d887ce0734ece516bf5d00915d09f5ab6e7faf7066c4be9
Deleted: sha256:714b5781d58457a51bceb68d161763ac3f2a660e42e499d46a7e4989be43085d
Deleted: sha256:80e35c4153f925f6f3f8d64f1a3e1ae25b3f6fcf0ed6c28293f09fcb5561408f
Deleted: sha256:71e93004a995f437779213ae7349a558e3fdad2fb8ef9f46550684378b57b189
Deleted: sha256:febd06c9f931f4e2af3be06fef0c4318d2e769944c0385e3125cb2c3006ef759
Deleted: sha256:ad7ce5de15d9668e12d1a1a4f67a2653800abc241c2c36e56569bd612e0dc50e
Deleted: sha256:d72965126554e7a85c88ef7141cb4436c82f8f152f87c089611fd39a812ddc4d
Deleted: sha256:345b1816846c262836b973cc6e1a03fb2f3a3658c8df87e88e9159302e6c6c89
Deleted: sha256:9175b42caba2d7d200011514fa8afcabe842b9efcb6918ec849f67db96eec0de
Deleted: sha256:ed5c3f28a472160c7f5fb9a8e9203b7171c5099b716f85f2bbc7ba54a799fca2
Deleted: sha256:2e7c3c616c5b22a2164b5b958e22a44dbb628f973857a0a009fc3c2f37372ac7
Deleted: sha256:b4ef1a803ab31acc0e9018b056d2796dbe538498db95894573d4840659e28c5f
Deleted: sha256:b459fd96bdbbfc459cb633cdd5726b5f52a7b9292d8de872b3d8a08c1eae2af6
Deleted: sha256:1c12fb93cd21f5e497cbc65dfae4654d3b0ce430186122c57bbbe22c1be403ce
Deleted: sha256:fda26d18998faccecebe9681dd3db698cc2ad6893bda4425a34ac02368dd7f7d
Deleted: sha256:805405ad52c0584ba18f02bf9c2b598b8ab425edbab9270f8554b4bc29d05484
Deleted: sha256:a6851c1931bc49f51e9272482699c868ec884d55ee76625e773eb21341e64e71
Deleted: sha256:11f7a8231fde948914e148013a040d4e8230863c7d2e619e33c1a2e4e187fdab
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:514023ae9b2f4e5b9d887ce0734ece516bf5d00915d09f5ab6e7faf7066c4be9
  Associated tags:
 - 20230301-083153
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-083153].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:514023ae9b2f4e5b9d887ce0734ece516bf5d00915d09f5ab6e7faf7066c4be9].
$ rm -rf /tmp/tmp.V4Xn5W2zl4
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301082028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fae6a61bbab771f86a8677a22655917201b5a431afbc184c6eb1eab29054dc31].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301082028
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301082028]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301082028] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b4256c425b71bc75f94eb36aa801a7d5d5fedac73ddac1c44b71fb2d1b29e865].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 906533.
Stopping expansion service pid: 906534.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 52s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1347

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1347/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-023147",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301022036",
            "environmentId": "sebNgJKXpibeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-023147"
      }
    ]
  },
  "name": "go-testxlang_partition-734",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/03/01 03:17:24 Submitted job: 2023-02-28_19_17_24-8448278598537687553
2023/03/01 03:17:24 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-28_19_17_24-8448278598537687553?project=apache-beam-testing
2023/03/01 03:17:24 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-28_19_17_24-8448278598537687553
2023/03/01 03:17:25 Job state: JOB_STATE_PENDING ...
2023/03/01 03:17:55 Job still running ...
2023/03/01 03:18:25 Job still running ...
2023/03/01 03:18:55 Job still running ...
2023/03/01 03:19:25 Job still running ...
2023/03/01 03:19:55 Job still running ...
2023/03/01 03:20:25 Job still running ...
2023/03/01 03:20:55 Job still running ...
2023/03/01 03:21:25 Job still running ...
2023/03/01 03:21:55 Job still running ...
2023/03/01 03:22:25 Job still running ...
2023/03/01 03:22:55 Job still running ...
2023/03/01 03:23:25 Job still running ...
2023/03/01 03:23:55 Job still running ...
2023/03/01 03:24:26 Job still running ...
2023/03/01 03:24:56 Job still running ...
2023/03/01 03:25:26 Job still running ...
2023/03/01 03:25:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-28_19_17_24-8448278598537687553 failed
--- FAIL: TestXLang_Partition (550.83s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3239.472s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677637950257004515
--- FAIL: TestBigQueryIO_BasicWriteRead (5.29s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38307 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lTigOIxmiZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lTigOIxmiZ"}}  windowing_strategies:{key:"w0@lTigOIxmiZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lTigOIxmiZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lTigOIxmiZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lTigOIxmiZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677637950257004515\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lTigOIxmiZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38307 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lTigOIxmiZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lTigOIxmiZ"}}  windowing_strategies:{key:"w0@lTigOIxmiZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lTigOIxmiZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lTigOIxmiZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lTigOIxmiZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677637950257004515\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lTigOIxmiZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 21 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000506580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000506580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e4a0?, 0xc0000bc2d0?}, {0x1138176, 0x39}, {0xc0004e80c0?, 0xa9cba0?, 0x1?}, {0xc000043dc0, 0xf}, 0xc00001fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e440?, 0xc0000bc2d0?}, {0xc00052e300, 0x52}, {0x1?}, {0xc00001fea8, 0x2, 0x7f1a34dd81f8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043dc0, 0xf}, {0xc00052e300, 0x52}, {0xeba5c0, 0xc00048c210})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004971e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004971e0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.323s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:56822286b56be38b3ff96cf90b898e4a45e72e95792c5b84c271df28ae4550c4
  Associated tags:
 - 20230301-023147
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-023147
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230301-023147].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:56822286b56be38b3ff96cf90b898e4a45e72e95792c5b84c271df28ae4550c4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b2f20914c0baf8d022ba769b4d4c8c490846878fdac293bb7392609e3fcf2da]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230301022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b2f20914c0baf8d022ba769b4d4c8c490846878fdac293bb7392609e3fcf2da])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b2f20914c0baf8d022ba769b4d4c8c490846878fdac293bb7392609e3fcf2da
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2b2f20914c0baf8d022ba769b4d4c8c490846878fdac293bb7392609e3fcf2da].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a8154b44b222a0781f2c874e19c094c0106e60adab5aa9c68dbc07fe550ec16a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230301022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a8154b44b222a0781f2c874e19c094c0106e60adab5aa9c68dbc07fe550ec16a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a8154b44b222a0781f2c874e19c094c0106e60adab5aa9c68dbc07fe550ec16a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a8154b44b222a0781f2c874e19c094c0106e60adab5aa9c68dbc07fe550ec16a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 14s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1346

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1346/display/redirect?page=changes>

Changes:

[noreply] Fix Python3.7 PostCommit Azure integration test (#25654)


------------------------------------------
[...truncated 1.05 MB...]
2023/02/28 22:01:47 Job still running ...
2023/02/28 22:02:17 Job still running ...
2023/02/28 22:02:47 Job still running ...
2023/02/28 22:03:17 Job still running ...
2023/02/28 22:03:47 Job still running ...
2023/02/28 22:04:17 Job still running ...
2023/02/28 22:04:47 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-28_13_56_16-5252027600324863179 failed
--- FAIL: TestXLang_Partition (551.69s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3186.208s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677618741279264948
--- FAIL: TestBigQueryIO_BasicWriteRead (5.48s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39551 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@zUeRSASYHn"  is_bounded:BOUNDED  windowing_strategy_id:"w0@zUeRSASYHn"}}  windowing_strategies:{key:"w0@zUeRSASYHn"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@zUeRSASYHn"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@zUeRSASYHn"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@zUeRSASYHn"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677618741279264948\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"zUeRSASYHn"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39551 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@zUeRSASYHn"  is_bounded:BOUNDED  windowing_strategy_id:"w0@zUeRSASYHn"}}  windowing_strategies:{key:"w0@zUeRSASYHn"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@zUeRSASYHn"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@zUeRSASYHn"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@zUeRSASYHn"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677618741279264948\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"zUeRSASYHn"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00029df00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00029df00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6e80?, 0xc0001399a0?}, {0x1138176, 0x39}, {0xc00015a0c0?, 0xa9cba0?, 0x1?}, {0xc0003f6d50, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6e20?, 0xc0001399a0?}, {0xc00010e900, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f8a96646998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d50, 0xf}, {0xc00010e900, 0x52}, {0xeba5c0, 0xc0001301a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000549040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000549040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.519s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-211133
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-211133
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cad6c44fe842bf3c8b957b7aebbde973fe30974d67075fc2a3011560b9f7d916
Deleted: sha256:3fc284e5a99ec570511c0fa595efe155fd55d18b657f5f7fcfa648e3189f9d48
Deleted: sha256:7cff4ac8505ac752386aad8ece0be84123dbd443445a0896cb77e787f560a714
Deleted: sha256:898cb7f05b70fcd4dd8ba26714946d97c4d7911c497809a834f35498366de32c
Deleted: sha256:509b1e2ce3fa887cb153fb1b25dd3d27021151b84fa543d59823a66ba817160b
Deleted: sha256:73203534a2919e8e545747248b43dd1bdd824a261154f1d9e9e3280926ebe541
Deleted: sha256:8d419577434c7f710d8e2f708b7cf84182469c6205e9a754d89c62cfce5c26e1
Deleted: sha256:26c32cc6639ff531bc87998a4b730a254e4203ef984f60a5c1eed59aaeceafb3
Deleted: sha256:44f960f82f84422894e44d775223db2651a73ffc2528de0f50917f0be8dc344b
Deleted: sha256:a7bd214178710ac5a2510718280ed74065c80ec3d6b461577b005b09b6961353
Deleted: sha256:c5acad396cec184b65c02c3beddce8071d2680bfa8cee476f47861d817213006
Deleted: sha256:d735e8138af4c03121bb7b01edb06f792d73cbfc59c7c0626f74d47e11e086ed
Deleted: sha256:24d62a334fb8ab846d500ef66557dce66e6fc7d26effaadbfa5f0b5d852c4109
Deleted: sha256:fc119102e963e271f1101e429948ea4310b2650a11cfad9a6a593b61f0fb48aa
Deleted: sha256:9864a353acd2ded693c103ea0f72176f3f049a36e43bd543195025bf2bfe626c
Deleted: sha256:8cd3d873c5d853812ff34647a64abd3b6895a9c63d4efc68dff744907df1c2d3
Deleted: sha256:02bf6e8a849e829a05a43360b46a131b883b16c680a1d7b0a1faca164a321ea4
Deleted: sha256:9a3e57897dc89797a92c843638f7503e62c26ba359a2791152e3e878aae31c47
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-211133
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cad6c44fe842bf3c8b957b7aebbde973fe30974d67075fc2a3011560b9f7d916
  Associated tags:
 - 20230228-211133
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-211133
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-211133].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:cad6c44fe842bf3c8b957b7aebbde973fe30974d67075fc2a3011560b9f7d916].
$ rm -rf /tmp/tmp.ZJXbldgncA
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228205802
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228205802]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228205802] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5fb88894dc2c93def21042f963aaf334cc6c527102f826c9e7996bf9a507b79c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228205802
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902
Deleted: sha256:7f896d11db53b560dcf1eedf0ffc8671dbd95dfb64dbf9c36fc54dc4eaa4626a
Deleted: sha256:61c47576023eced631aeeb39e70c365d4e731434e3017a165929068689b596ff
Deleted: sha256:ece6ed36102d5e2dfb25033edc74d27c5c5f85d9b780374e29148f77786a1316
Deleted: sha256:e1c547a2ea332c08ed905fbdd0624582a15b40771596da5bfea39313381a491c
Deleted: sha256:c65d8c863807d0bb2a88cda4e2a7c61e040e987d4ac9992bcede3341d6642cdb
Deleted: sha256:55e11c96de1a0a680548d5ae90280a19bcb793ebbdef76de213576bfd0fb64fb
Deleted: sha256:8b87233a9023ab8ae51b10fa756cb87a76c22e43839c1d70dc213bb2cec2a653
Deleted: sha256:758a773a7febeaff73ac3e06c7d5999cf3e0aa77274846ba825a6227cecd3463
Deleted: sha256:82bc9f9ddf442d12ea399be6d29e53400ebdadfd0b65c40afc0a41b9079b873a
Deleted: sha256:48b993cf1cfdb02a258c6e8aa2e4354d76e97dc40dbaca003711f255d28aa173
Deleted: sha256:86977e431c5cd0c44c5f8deef7db71315737b4b965e4715e63174b08b77d0657
Deleted: sha256:f1f9bf5fad21adff5f70e1ded05e47e8e044c12b53ed53ec47dc748839d4e0f2
Deleted: sha256:249c265d53399e3290c3ccdf7af5de8d70e62aa5c2abb83c8e3b3d4434d58341
Deleted: sha256:cb6b6cf55b4553d05c7cfa4ec02fd91a7dee193af269ab41e503af0a115b2a78
Deleted: sha256:70397ffc89b65c4b5c0b0743775ffa0e0e8e367c78b5465ac185383c1f98ce94
Deleted: sha256:7ebce2420e3570588c6c894b936208ab396f3ab2c17fb4d8b2f1b9f3e7d0b1a5
Deleted: sha256:ee44a68de07065a507f53a6500fcfa833b25e2155e8e3b4d44078438d2d43584
Deleted: sha256:4a3ed25da51d0a5085653d7f498ce49aeb147fa94fa9482109bea6130f596da5
Deleted: sha256:7d89308e6f44063a5bab77991cd1e8fff13b304df4026f69b4edd08f66018d25
Deleted: sha256:fc53b4b98ef8ad0355bfbca010c684f5f54ed65e80578ed211faf99be30449c0
Deleted: sha256:a8b7171c7d45b1bb9176f86bb07695abf82927b3f73ee3db834d6b5fb68432ca
Deleted: sha256:9b621d7f8d9e24c9571dc0195e179dff94e59d9ad5f56dab3bf2163e955b5b0d
Deleted: sha256:296701ab01993c7de662ce91903b72544c738db20fca93d0198bdf7bdf092eb8
Deleted: sha256:35f3148b528c88f5c891cccf22bd2a3e1f032cf8b0baec4655078d01bf066f89
Deleted: sha256:16862f03c932de5673759284cf5f4b8b28d3d55a6b73620264fb90d5bcc14f40
Deleted: sha256:c2fdbfc4bdf4c7789e6ebedd6ad5a3bf65a85918648b56660a8aa5164b0773e5
Deleted: sha256:053d3b6f12030cdcc4aee572fbda4cfddf76cb1f0203b986a2687cd2d7603b29
Deleted: sha256:f7ea436ac40bd0c7e77b78dfba0bd1137cf51d671242b3290c59c98c4cd90e21
Deleted: sha256:c839ab185dca3790c66f02c94c4998bf59c63c29d5d908b3d3faac23cc3e4180
Deleted: sha256:d345c5fe52ea1fa9f2786b5080a484287eb8ba255d505d506805e8604963b8ba
Deleted: sha256:7ed3be0375c882a12d7dd1c64861cbfa1b01c1a5f708b32ecd109efb5da0e090
Deleted: sha256:1018e280084843ac97ec09fff9dd6345c0cfcbe76352df729172228fe945b260
Deleted: sha256:d9e4503a4ccf101378d935863e75126933e4c3808466fa246417b6d73aa5d139
Deleted: sha256:2d4a3292f17177683bd1bc95bc38db11f94cb89a37dc8b492e3d75b22ce0d090
Deleted: sha256:d0130d7a7cf4871b4601c8defcde978bce038c7d8460d795913ed84395fc2f8e
Deleted: sha256:de519979947504a26a120095ac6972b714f0a9e4ff84444f6671b59d88331c06
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228205802]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228205802] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3ef9049344d84b68a7cde974434391a4d6b6df611959c953b47fbb1667971902].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1174428.
Stopping expansion service pid: 1174429.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 46s
232 actionable tasks: 158 executed, 62 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1345

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1345/display/redirect>

Changes:


------------------------------------------
[...truncated 554.98 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-143906",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228142223",
            "environmentId": "PMaVaXJKChbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-143906"
      }
    ]
  },
  "name": "go-testxlang_partition-96",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/28 15:24:36 Submitted job: 2023-02-28_07_24_36-2210116273326867012
2023/02/28 15:24:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-28_07_24_36-2210116273326867012?project=apache-beam-testing
2023/02/28 15:24:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-28_07_24_36-2210116273326867012
2023/02/28 15:24:36 Job state: JOB_STATE_PENDING ...
2023/02/28 15:25:06 Job still running ...
2023/02/28 15:25:36 Job still running ...
2023/02/28 15:26:06 Job still running ...
2023/02/28 15:26:36 Job still running ...
2023/02/28 15:27:07 Job still running ...
2023/02/28 15:27:37 Job still running ...
2023/02/28 15:28:07 Job still running ...
2023/02/28 15:28:37 Job still running ...
2023/02/28 15:29:07 Job still running ...
2023/02/28 15:29:37 Job still running ...
2023/02/28 15:30:07 Job still running ...
2023/02/28 15:30:37 Job still running ...
2023/02/28 15:31:07 Job still running ...
2023/02/28 15:31:37 Job still running ...
2023/02/28 15:32:07 Job still running ...
2023/02/28 15:32:37 Job still running ...
2023/02/28 15:33:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-28_07_24_36-2210116273326867012 failed
--- FAIL: TestXLang_Partition (550.52s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3216.706s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677595210822828043
--- FAIL: TestBigQueryIO_BasicWriteRead (5.46s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40967 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@nAjfDspsQE"  is_bounded:BOUNDED  windowing_strategy_id:"w0@nAjfDspsQE"}}  windowing_strategies:{key:"w0@nAjfDspsQE"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@nAjfDspsQE"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@nAjfDspsQE"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@nAjfDspsQE"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677595210822828043\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"nAjfDspsQE"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40967 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@nAjfDspsQE"  is_bounded:BOUNDED  windowing_strategy_id:"w0@nAjfDspsQE"}}  windowing_strategies:{key:"w0@nAjfDspsQE"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@nAjfDspsQE"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@nAjfDspsQE"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@nAjfDspsQE"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677595210822828043\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"nAjfDspsQE"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00052a480})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00052a480})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6700?, 0xc0000d6050?}, {0x1138176, 0x39}, {0xc000154180?, 0xa9cba0?, 0x1?}, {0xc000042d10, 0xf}, 0xc0001ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a66a0?, 0xc0000d6050?}, {0xc00004c540, 0x52}, {0x1?}, {0xc0001ebea8, 0x2, 0x7f162c7e5320?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d10, 0xf}, {0xc00004c540, 0x52}, {0xeba5c0, 0xc00046c100})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ca9c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ca9c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.496s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.041s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.043s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1183961970a484d1a11f803e407e7bd4e24a5495a99b6400ae26a58c44616526
  Associated tags:
 - 20230228-143906
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-143906
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-143906].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1183961970a484d1a11f803e407e7bd4e24a5495a99b6400ae26a58c44616526].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228142223]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:82dc91531fdc538831a365ca5cc63a13d2c67220abfa1d80334cd9ae34cdd0e3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228142223] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:82dc91531fdc538831a365ca5cc63a13d2c67220abfa1d80334cd9ae34cdd0e3])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:82dc91531fdc538831a365ca5cc63a13d2c67220abfa1d80334cd9ae34cdd0e3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:82dc91531fdc538831a365ca5cc63a13d2c67220abfa1d80334cd9ae34cdd0e3].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228142223]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b27802e660f6e9573533227795a7b161d98b244e5c0945aef525ab8237d6d70]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228142223] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b27802e660f6e9573533227795a7b161d98b244e5c0945aef525ab8237d6d70])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b27802e660f6e9573533227795a7b161d98b244e5c0945aef525ab8237d6d70
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b27802e660f6e9573533227795a7b161d98b244e5c0945aef525ab8237d6d70].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 12m 23s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1344

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1344/display/redirect>

Changes:


------------------------------------------
[...truncated 575.96 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228082038",
            "environmentId": "JXDHIwuVsEbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206"
      }
    ]
  },
  "name": "go-testxlang_partition-457",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/28 09:16:37 Submitted job: 2023-02-28_01_16_36-8681678654567420520
2023/02/28 09:16:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-28_01_16_36-8681678654567420520?project=apache-beam-testing
2023/02/28 09:16:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-28_01_16_36-8681678654567420520
2023/02/28 09:16:37 Job state: JOB_STATE_PENDING ...
2023/02/28 09:17:07 Job still running ...
2023/02/28 09:17:37 Job still running ...
2023/02/28 09:18:07 Job still running ...
2023/02/28 09:18:37 Job still running ...
2023/02/28 09:19:07 Job still running ...
2023/02/28 09:19:37 Job still running ...
2023/02/28 09:20:07 Job still running ...
2023/02/28 09:20:37 Job still running ...
2023/02/28 09:21:07 Job still running ...
2023/02/28 09:21:37 Job still running ...
2023/02/28 09:22:07 Job still running ...
2023/02/28 09:22:37 Job still running ...
2023/02/28 09:23:07 Job still running ...
2023/02/28 09:23:38 Job still running ...
2023/02/28 09:24:08 Job still running ...
2023/02/28 09:24:38 Job still running ...
2023/02/28 09:25:08 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-28_01_16_36-8681678654567420520 failed
--- FAIL: TestXLang_Partition (551.69s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3179.804s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677573161755243286
--- FAIL: TestBigQueryIO_BasicWriteRead (4.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46023 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@TpKQfgGcIW"  is_bounded:BOUNDED  windowing_strategy_id:"w0@TpKQfgGcIW"}}  windowing_strategies:{key:"w0@TpKQfgGcIW"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@TpKQfgGcIW"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@TpKQfgGcIW"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@TpKQfgGcIW"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677573161755243286\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"TpKQfgGcIW"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46023 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@TpKQfgGcIW"  is_bounded:BOUNDED  windowing_strategy_id:"w0@TpKQfgGcIW"}}  windowing_strategies:{key:"w0@TpKQfgGcIW"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@TpKQfgGcIW"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@TpKQfgGcIW"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@TpKQfgGcIW"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677573161755243286\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"TpKQfgGcIW"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00069ef40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00069ef40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000488f40?, 0xc00048d680?}, {0x1138176, 0x39}, {0xc0001aa000?, 0xa9cba0?, 0x1?}, {0xc0003fae10, 0xf}, 0xc0005fdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488ee0?, 0xc00048d680?}, {0xc000690600, 0x52}, {0x1?}, {0xc0005fdea8, 0x2, 0x7f2d30be6448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fae10, 0xf}, {0xc000690600, 0x52}, {0xeba5c0, 0xc000042480})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.483s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.044s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7f293d1378a0e58aa3be96eb7b2368b4dea8fb4038f13cb2e6354fc5074cd0fa
Deleted: sha256:dc136bf8995e635f24e5112ec9732a887f0e6bc9382ab7d4c4c4c176f5a61541
Deleted: sha256:f2c3be45fb5a913db3915bb67897be295f6dd0839e5d1a133ba3f92a73407471
Deleted: sha256:3db0f443a5b638fc76355343f88a18fdd88a2ddb9ecc418ea70417c433bfe27d
Deleted: sha256:c535b4f6ac28700c03e1165e5fc397251b8e5371fb53e54c6b626dc1a292f4da
Deleted: sha256:ca1cb6940d3c56246e12a6df8f05e29f7dd2631f091088877614267ff0637cd8
Deleted: sha256:3654df77b9b6f464842c106e30beb9beea406cb7c8e65d11e2b59cf3bd0bc821
Deleted: sha256:a6e3ddd6b02b446c787673e299949f0587dbdebaa347576b2ed61b8ce87f1cc2
Deleted: sha256:0c5c3aed5a71f4c15ec5ed4696906931aaf78fdc1ac55c7cc97ae178a120f35f
Deleted: sha256:aeb3d54e4b4993654340bdd7a9669bf3b9485ed6ce9a02b8c7806c516ce2f13d
Deleted: sha256:bdea6cd72c9f0db650c9e3cf93ec2b660a6913eaaccec240103802eb0e553db9
Deleted: sha256:b868bce9ff7516d75fbe0cd39ee09940cdc53f819beed1509691ac9694a4e6e3
Deleted: sha256:b7cff685e42da83746dfccb7a9fab64781e5d31d25d64fb34918471373fef9b8
Deleted: sha256:d34f49aaff4d6566e9169b32834a5bbadf23e0386309da7b55cef35f2437f195
Deleted: sha256:8fdae6807e66c5f363382761d3653042c10c3d824186f29d2bd56200e39ae461
Deleted: sha256:6070c7546402e27a2325b04148385540460ac3148d15d13485bb2486b020d847
Deleted: sha256:e47d453b8a35a4b2d0fdf59871726eccda6faf2558a88d023c30ee4174b4fdbb
Deleted: sha256:e4c7d28915e83d2027d9f10238e8f0f0fc33826e4494f106117732b5eedad5da
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7f293d1378a0e58aa3be96eb7b2368b4dea8fb4038f13cb2e6354fc5074cd0fa
  Associated tags:
 - 20230228-083206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-083206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7f293d1378a0e58aa3be96eb7b2368b4dea8fb4038f13cb2e6354fc5074cd0fa].
$ rm -rf /tmp/tmp.J3CVDAq0Pp
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228082038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0f73539dc57434dfbb59352a9af1cfbb2529e406d9d223a13ea0628c867472db].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228082038
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cb3d96640dd392c550e7608a4afdba583861d0d546c2ae2c6ed5dc775e1e88e7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2738553.
Stopping expansion service pid: 2738554.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 26s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1343

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1343/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228022026",
            "environmentId": "bZqNXQsckcbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133"
      }
    ]
  },
  "name": "go-testxlang_partition-447",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/28 03:16:30 Submitted job: 2023-02-27_19_16_30-12574301913865716656
2023/02/28 03:16:30 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-27_19_16_30-12574301913865716656?project=apache-beam-testing
2023/02/28 03:16:30 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-27_19_16_30-12574301913865716656
2023/02/28 03:16:30 Job state: JOB_STATE_PENDING ...
2023/02/28 03:17:00 Job still running ...
2023/02/28 03:17:30 Job still running ...
2023/02/28 03:18:00 Job still running ...
2023/02/28 03:18:30 Job still running ...
2023/02/28 03:19:00 Job still running ...
2023/02/28 03:19:31 Job still running ...
2023/02/28 03:20:01 Job still running ...
2023/02/28 03:20:31 Job still running ...
2023/02/28 03:21:01 Job still running ...
2023/02/28 03:21:31 Job still running ...
2023/02/28 03:22:01 Job still running ...
2023/02/28 03:22:31 Job still running ...
2023/02/28 03:23:01 Job still running ...
2023/02/28 03:23:31 Job still running ...
2023/02/28 03:24:01 Job still running ...
2023/02/28 03:24:31 Job still running ...
2023/02/28 03:25:01 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-27_19_16_30-12574301913865716656 failed
--- FAIL: TestXLang_Partition (550.39s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3206.162s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677551528782437257
--- FAIL: TestBigQueryIO_BasicWriteRead (5.07s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33235 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@VhjwKlmEiN"  is_bounded:BOUNDED  windowing_strategy_id:"w0@VhjwKlmEiN"}}  windowing_strategies:{key:"w0@VhjwKlmEiN"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@VhjwKlmEiN"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@VhjwKlmEiN"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@VhjwKlmEiN"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677551528782437257\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"VhjwKlmEiN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33235 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@VhjwKlmEiN"  is_bounded:BOUNDED  windowing_strategy_id:"w0@VhjwKlmEiN"}}  windowing_strategies:{key:"w0@VhjwKlmEiN"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@VhjwKlmEiN"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@VhjwKlmEiN"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@VhjwKlmEiN"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677551528782437257\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"VhjwKlmEiN"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000464e00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000464e00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004a4c80?, 0xc0004b3630?}, {0x1138176, 0x39}, {0xc0000f00c0?, 0xa9cba0?, 0x1?}, {0xc000482c70, 0xf}, 0xc00001fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004a4c20?, 0xc0004b3630?}, {0xc0004b0300, 0x52}, {0x1?}, {0xc00001fea8, 0x2, 0x7f819ae0c420?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000482c70, 0xf}, {0xc0004b0300, 0x52}, {0xeba5c0, 0xc000483f80})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000493040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000493040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.105s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f70073059cf5b095e8e7aa5ab445494e99a20e9271fd965cce73e318a246e834
Deleted: sha256:eeb41dc10a81d9f3cf153f0f748f1eb84c1919efd98ba42d23824e30b1300e00
Deleted: sha256:f214ccf818c936b1fd04b5132d5de53d6b6b1e818ca58b08b483cfcba8b03b9a
Deleted: sha256:93e2902999863b0d14c86f50ac6d0ff2af62e747f98e1ae5ded8a62764ceb047
Deleted: sha256:49c1b7f8bb696bc1a3c69a8bbde84dbe5bdb141943fb48c26c9d9c6557f8cf3d
Deleted: sha256:670a9a7af90f4e03dc4e7cca67820101c720b49cb90871969f96c4360fd23083
Deleted: sha256:cfc20ae8cd43dbbc11b736d7f1805c1b609cfe58b57f6ab6aef644a36857e6d1
Deleted: sha256:0238f7e62694ff00a5710659017303b43bf3b233247f09c802664fe4834476ba
Deleted: sha256:d882147b18efa4e004ef4c05b125a1c10814e2107b13792c1da45a7a346921c0
Deleted: sha256:8a09b41abaf374e055a8d3a005add60ddc3708058d173e12a111cf7d07b03031
Deleted: sha256:a3714ff6f750cee381e63c479368dd290e80dc0ddf63872d15f7fe77c73e1e46
Deleted: sha256:37c1f3b83ebfd48a22ddcd54778393415c03afefc89bc52db06ee4e9cb3ef9a2
Deleted: sha256:7c489767ea5aa198546f305bfee4ac5615024ba182e2f492c2ba499accf37306
Deleted: sha256:7515621a46d517a0b1bbc5575d8be52d3b1239f0b8c852b596bb2539df272820
Deleted: sha256:b9beef17919ff86a773c5c6a4d1ad69cbdf45f1bcf21e6e60ae0a3c5c89b5a37
Deleted: sha256:9c42430672908eb25709fb9340cab221ecfb3eb164b81f7508e35ce2108fbbfd
Deleted: sha256:5d7e7587ca475c667504a8c046fe6589561c7f3a1a4688147ce9b8ba98072bd5
Deleted: sha256:5fc47755f8d0ceeccbbed75c466310098a856eeddea430dbb7fcd8d05e46c010
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f70073059cf5b095e8e7aa5ab445494e99a20e9271fd965cce73e318a246e834
  Associated tags:
 - 20230228-023133
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230228-023133].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f70073059cf5b095e8e7aa5ab445494e99a20e9271fd965cce73e318a246e834].
$ rm -rf /tmp/tmp.Z3MBCDYBee
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228022026
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228022026]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230228022026] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c831014ebecfd3e9cab0d2ec62990a53630194109352945ab18f3f754eea0c83].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228022026
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228022026]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230228022026] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:24d208f67ec43a290b166548b07cc6dba1d1392e7f513d5ea24d725800b648b3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2531778.
Stopping expansion service pid: 2531779.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 31s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1342

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1342/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227202048",
            "environmentId": "kGesPZzfvVbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548"
      }
    ]
  },
  "name": "go-testxlang_partition-635",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/27 21:21:26 Submitted job: 2023-02-27_13_21_26-1867674186678031454
2023/02/27 21:21:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-27_13_21_26-1867674186678031454?project=apache-beam-testing
2023/02/27 21:21:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-27_13_21_26-1867674186678031454
2023/02/27 21:21:26 Job state: JOB_STATE_PENDING ...
2023/02/27 21:21:56 Job still running ...
2023/02/27 21:22:27 Job still running ...
2023/02/27 21:22:57 Job still running ...
2023/02/27 21:23:27 Job still running ...
2023/02/27 21:23:57 Job still running ...
2023/02/27 21:24:27 Job still running ...
2023/02/27 21:24:57 Job still running ...
2023/02/27 21:25:27 Job still running ...
2023/02/27 21:25:57 Job still running ...
2023/02/27 21:26:27 Job still running ...
2023/02/27 21:26:57 Job still running ...
2023/02/27 21:27:27 Job still running ...
2023/02/27 21:27:57 Job still running ...
2023/02/27 21:28:27 Job still running ...
2023/02/27 21:28:57 Job still running ...
2023/02/27 21:29:27 Job still running ...
2023/02/27 21:29:57 Job still running ...
2023/02/27 21:30:27 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-27_13_21_26-1867674186678031454 failed
--- FAIL: TestXLang_Partition (583.00s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3271.271s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677530194623507021
--- FAIL: TestBigQueryIO_BasicWriteRead (5.54s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40299 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wgWTVQRoQH"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wgWTVQRoQH"}}  windowing_strategies:{key:"w0@wgWTVQRoQH"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wgWTVQRoQH"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wgWTVQRoQH"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wgWTVQRoQH"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677530194623507021\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wgWTVQRoQH"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40299 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wgWTVQRoQH"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wgWTVQRoQH"}}  windowing_strategies:{key:"w0@wgWTVQRoQH"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wgWTVQRoQH"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wgWTVQRoQH"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wgWTVQRoQH"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677530194623507021\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wgWTVQRoQH"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00015ecc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00015ecc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169000?, 0xc000138280?}, {0x1138176, 0x39}, {0xc00015a180?, 0xa9cba0?, 0x1?}, {0xc000131d30, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168fa0?, 0xc000138280?}, {0xc00004c540, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0x7fbd988d5250?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131d30, 0xf}, {0xc00004c540, 0x52}, {0xeba5c0, 0xc0003f6210})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000491040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000491040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.569s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5bebc81792a45297f3b71122dcb7ed492031b7d2c31bb12eb1bffd584497b026
Deleted: sha256:5977f25b86220afd23cc9f613047d10d085c1efc51b0e00bc29050cbf4ed24f9
Deleted: sha256:a016b371f5e17f00ff834c93c4e73724c2befcc3023a009e09635509e00208f6
Deleted: sha256:d1a5ef6520f4f473f5e2467acbc306ed1c603cbb464def1f3b313fc54d6f9795
Deleted: sha256:cfe699d608f597ff97978608019b3819b8cd5bd11e3c5b7526fcaada9282259b
Deleted: sha256:e554b5205d8e4600dc40d28e19ea7212b6537d847632b3fcf6855d2cec82083f
Deleted: sha256:2d9687f644b567f4079c587444e514311cf68383eba04f8429e0d801441275cc
Deleted: sha256:9c3b82949afabed98572ad2c574cac794672838e0a308c787757703216e9d5cd
Deleted: sha256:900b24fd1c27a1ebcbac6f0287f1860cf04b0158823912e82c6f057e75d0da93
Deleted: sha256:1150a2ec902796039818484aa259823126c27410bd5a432986a9e8c5271bccff
Deleted: sha256:742d9dee24f462d7eec7d8d9041bcb4d9f2e622d50f6c88330e5b8ff7183e968
Deleted: sha256:9ea5bef0ad0ce2caa5f6249bd960aee01fdfc213b7a9d3215f8171fb3a3791f5
Deleted: sha256:591cf3adb28f39332ef1a96120969946dbfeb4dd00ec8b258217c759abc50438
Deleted: sha256:61a3883b327a80c93cf79ebc5c600b737447fcdb0e9444759005799746c2d3dd
Deleted: sha256:a21c2b1c25d1a1eeb677e4c476e4d9f87a09558c280c3a8641bd17c7e9b43bfc
Deleted: sha256:1f782c69f9c6dd5dadf78fa85ffffb66d1017f6f38a761037150aeb03c2d4277
Deleted: sha256:2e8c56f1c4c0d40bb49a4e99ffedee3e88abba2d02dc79db72b7efeae19be6a5
Deleted: sha256:67e101ce35add2b96291c865b8043b069771b290a31e7b16c389e0ab659e381e
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5bebc81792a45297f3b71122dcb7ed492031b7d2c31bb12eb1bffd584497b026
  Associated tags:
 - 20230227-203548
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-203548].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5bebc81792a45297f3b71122dcb7ed492031b7d2c31bb12eb1bffd584497b026].
$ rm -rf /tmp/tmp.OpOrYuNyw4
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227202048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec9a0a730d71665af5861807f4047b481d62826436efb84d3fe11f9493ebc06a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227202048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:47b8937d43e7c6921d624193f57897ca9c57c92cb5bd34d734f1302cc7ed86bd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2687581.
Stopping expansion service pid: 2687582.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 43s
232 actionable tasks: 161 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1341

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1341/display/redirect?page=changes>

Changes:

[noreply] Bump github.com/aws/aws-sdk-go-v2/feature/s3/manager in /sdks (#25637)


------------------------------------------
[...truncated 1007.49 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-145217",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227143930",
            "environmentId": "jMgYiwXtjYbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-145217"
      }
    ]
  },
  "name": "go-testxlang_partition-149",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/27 15:37:00 Submitted job: 2023-02-27_07_36_59-16273721148597897630
2023/02/27 15:37:00 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-27_07_36_59-16273721148597897630?project=apache-beam-testing
2023/02/27 15:37:00 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-27_07_36_59-16273721148597897630
2023/02/27 15:37:00 Job state: JOB_STATE_PENDING ...
2023/02/27 15:37:30 Job still running ...
2023/02/27 15:38:00 Job still running ...
2023/02/27 15:38:30 Job still running ...
2023/02/27 15:39:00 Job still running ...
2023/02/27 15:39:30 Job still running ...
2023/02/27 15:40:00 Job still running ...
2023/02/27 15:40:30 Job still running ...
2023/02/27 15:41:00 Job still running ...
2023/02/27 15:41:30 Job still running ...
2023/02/27 15:42:01 Job still running ...
2023/02/27 15:42:31 Job still running ...
2023/02/27 15:43:01 Job still running ...
2023/02/27 15:43:31 Job still running ...
2023/02/27 15:44:01 Job still running ...
2023/02/27 15:44:31 Job still running ...
2023/02/27 15:45:01 Job still running ...
2023/02/27 15:45:31 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-27_07_36_59-16273721148597897630 failed
--- FAIL: TestXLang_Partition (550.91s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3178.902s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677509594286254264
--- FAIL: TestBigQueryIO_BasicWriteRead (6.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42955 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@YHBZZwaKkm"  is_bounded:BOUNDED  windowing_strategy_id:"w0@YHBZZwaKkm"}}  windowing_strategies:{key:"w0@YHBZZwaKkm"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@YHBZZwaKkm"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@YHBZZwaKkm"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@YHBZZwaKkm"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677509594286254264\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"YHBZZwaKkm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42955 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@YHBZZwaKkm"  is_bounded:BOUNDED  windowing_strategy_id:"w0@YHBZZwaKkm"}}  windowing_strategies:{key:"w0@YHBZZwaKkm"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@YHBZZwaKkm"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@YHBZZwaKkm"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@YHBZZwaKkm"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677509594286254264\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"YHBZZwaKkm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0002fad40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0002fad40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048c740?, 0xc000138230?}, {0x1138176, 0x39}, {0xc0002d80c0?, 0xa9cba0?, 0x1?}, {0xc000591460, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048c6e0?, 0xc000138230?}, {0xc0005b6780, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000591460, 0xf}, {0xc0005b6780, 0x52}, {0xeba5c0, 0xc0003f4118})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ab040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ab040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.603s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.052s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e14425af68b6d191e19289776cb4422b093ce8a05c887d7a8a146de1f307e1be
  Associated tags:
 - 20230227-145217
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-145217
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-145217].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e14425af68b6d191e19289776cb4422b093ce8a05c887d7a8a146de1f307e1be].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227143930]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b30d4bef5f5e66142fa4e48b96d0faae1d34b0381f06042ba1004f5fb89e854c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227143930] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b30d4bef5f5e66142fa4e48b96d0faae1d34b0381f06042ba1004f5fb89e854c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b30d4bef5f5e66142fa4e48b96d0faae1d34b0381f06042ba1004f5fb89e854c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b30d4bef5f5e66142fa4e48b96d0faae1d34b0381f06042ba1004f5fb89e854c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227143930]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fb30bb78d98ce799b2906b6db6741eef40edfe1c1a86166f4f19bc91d4224517]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227143930] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fb30bb78d98ce799b2906b6db6741eef40edfe1c1a86166f4f19bc91d4224517])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fb30bb78d98ce799b2906b6db6741eef40edfe1c1a86166f4f19bc91d4224517
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:fb30bb78d98ce799b2906b6db6741eef40edfe1c1a86166f4f19bc91d4224517].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 57s
232 actionable tasks: 160 executed, 60 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1340

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1340/display/redirect>

Changes:


------------------------------------------
[...truncated 1020.35 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-083150",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227082041",
            "environmentId": "ichatcVPJYbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-083150"
      }
    ]
  },
  "name": "go-testxlang_partition-502",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/27 09:16:54 Submitted job: 2023-02-27_01_16_53-8295077089596095242
2023/02/27 09:16:54 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-27_01_16_53-8295077089596095242?project=apache-beam-testing
2023/02/27 09:16:54 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-27_01_16_53-8295077089596095242
2023/02/27 09:16:54 Job state: JOB_STATE_PENDING ...
2023/02/27 09:17:24 Job still running ...
2023/02/27 09:17:54 Job still running ...
2023/02/27 09:18:24 Job still running ...
2023/02/27 09:18:54 Job still running ...
2023/02/27 09:19:24 Job still running ...
2023/02/27 09:19:54 Job still running ...
2023/02/27 09:20:24 Job still running ...
2023/02/27 09:20:54 Job still running ...
2023/02/27 09:21:24 Job still running ...
2023/02/27 09:21:54 Job still running ...
2023/02/27 09:22:24 Job still running ...
2023/02/27 09:22:54 Job still running ...
2023/02/27 09:23:24 Job still running ...
2023/02/27 09:23:54 Job still running ...
2023/02/27 09:24:25 Job still running ...
2023/02/27 09:24:55 Job still running ...
2023/02/27 09:25:25 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-27_01_16_53-8295077089596095242 failed
--- FAIL: TestXLang_Partition (551.17s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.440s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677486747915736559
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42919 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ccRBqjhreK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ccRBqjhreK"}}  windowing_strategies:{key:"w0@ccRBqjhreK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ccRBqjhreK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ccRBqjhreK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ccRBqjhreK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677486747915736559\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ccRBqjhreK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42919 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ccRBqjhreK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ccRBqjhreK"}}  windowing_strategies:{key:"w0@ccRBqjhreK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ccRBqjhreK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ccRBqjhreK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ccRBqjhreK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677486747915736559\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ccRBqjhreK"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 55 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0004765c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0004765c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480f80?, 0xc0004bb680?}, {0x1138176, 0x39}, {0xc00015e0c0?, 0xa9cba0?, 0x1?}, {0xc000042d80, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480f20?, 0xc0004bb680?}, {0xc0001188a0, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f80b40ee800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d80, 0xf}, {0xc0001188a0, 0x52}, {0xeba5c0, 0xc000136230})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000338680)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000338680, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.435s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:61c1e00ed1e11bde92c2fa479397e9dc84c07e159e460cb081cd0615643ba1bf
  Associated tags:
 - 20230227-083150
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-083150
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-083150].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:61c1e00ed1e11bde92c2fa479397e9dc84c07e159e460cb081cd0615643ba1bf].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1ee8f70fa3b8d9ccc3b4080ef01d7b306b43cdb35b83a1fcb5a2058b2f8b5ccd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1ee8f70fa3b8d9ccc3b4080ef01d7b306b43cdb35b83a1fcb5a2058b2f8b5ccd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1ee8f70fa3b8d9ccc3b4080ef01d7b306b43cdb35b83a1fcb5a2058b2f8b5ccd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1ee8f70fa3b8d9ccc3b4080ef01d7b306b43cdb35b83a1fcb5a2058b2f8b5ccd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4e3007e3510460c1d8fb7c8afcafc1c9fbf9401698c0bee819c5cba1ec8b667d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4e3007e3510460c1d8fb7c8afcafc1c9fbf9401698c0bee819c5cba1ec8b667d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4e3007e3510460c1d8fb7c8afcafc1c9fbf9401698c0bee819c5cba1ec8b667d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4e3007e3510460c1d8fb7c8afcafc1c9fbf9401698c0bee819c5cba1ec8b667d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 43s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1339

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1339/display/redirect>

Changes:


------------------------------------------
[...truncated 1019.53 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-023138",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227022036",
            "environmentId": "JXoEiroyEwbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-023138"
      }
    ]
  },
  "name": "go-testxlang_partition-322",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/27 03:15:05 Submitted job: 2023-02-26_19_15_04-17006424758577831632
2023/02/27 03:15:05 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-26_19_15_04-17006424758577831632?project=apache-beam-testing
2023/02/27 03:15:05 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-26_19_15_04-17006424758577831632
2023/02/27 03:15:05 Job state: JOB_STATE_PENDING ...
2023/02/27 03:15:35 Job still running ...
2023/02/27 03:16:05 Job still running ...
2023/02/27 03:16:35 Job still running ...
2023/02/27 03:17:05 Job still running ...
2023/02/27 03:17:35 Job still running ...
2023/02/27 03:18:05 Job still running ...
2023/02/27 03:18:35 Job still running ...
2023/02/27 03:19:05 Job still running ...
2023/02/27 03:19:35 Job still running ...
2023/02/27 03:20:05 Job still running ...
2023/02/27 03:20:35 Job still running ...
2023/02/27 03:21:05 Job still running ...
2023/02/27 03:21:36 Job still running ...
2023/02/27 03:22:06 Job still running ...
2023/02/27 03:22:36 Job still running ...
2023/02/27 03:23:06 Job still running ...
2023/02/27 03:23:36 Job still running ...
2023/02/27 03:24:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-26_19_15_04-17006424758577831632 failed
--- FAIL: TestXLang_Partition (580.27s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3147.102s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677465132761146749
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34051 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qvbdNebBaz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qvbdNebBaz"}}  windowing_strategies:{key:"w0@qvbdNebBaz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qvbdNebBaz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qvbdNebBaz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qvbdNebBaz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677465132761146749\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qvbdNebBaz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34051 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qvbdNebBaz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qvbdNebBaz"}}  windowing_strategies:{key:"w0@qvbdNebBaz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qvbdNebBaz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qvbdNebBaz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qvbdNebBaz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677465132761146749\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qvbdNebBaz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000033540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000033540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00064e0e0?, 0xc00066a0f0?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc00011d880, 0xf}, 0xc0001a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00064e080?, 0xc00066a0f0?}, {0xc00004cc00, 0x52}, {0x1?}, {0xc0001a9ea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011d880, 0xf}, {0xc00004cc00, 0x52}, {0xeba5c0, 0xc0000420a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005836c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005836c0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.363s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.040s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2e57d345fc710b6ec5fa41d546f203ab37cfeefc439e300cc8d943718acd654f
  Associated tags:
 - 20230227-023138
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-023138
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230227-023138].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2e57d345fc710b6ec5fa41d546f203ab37cfeefc439e300cc8d943718acd654f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:33dcca374a5d41da23728727d0a9b08d56fe34ad954128e3408062304f45e7a4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230227022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:33dcca374a5d41da23728727d0a9b08d56fe34ad954128e3408062304f45e7a4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:33dcca374a5d41da23728727d0a9b08d56fe34ad954128e3408062304f45e7a4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:33dcca374a5d41da23728727d0a9b08d56fe34ad954128e3408062304f45e7a4].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227022036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423407861fd490548ad691f535817705451c23aba8524d0c09d79f6845db9a6c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230227022036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423407861fd490548ad691f535817705451c23aba8524d0c09d79f6845db9a6c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423407861fd490548ad691f535817705451c23aba8524d0c09d79f6845db9a6c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423407861fd490548ad691f535817705451c23aba8524d0c09d79f6845db9a6c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 24s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1338

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1338/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226202030",
            "environmentId": "unSnUvWqlabeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150"
      }
    ]
  },
  "name": "go-testxlang_partition-628",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/26 21:16:14 Submitted job: 2023-02-26_13_16_14-8777180321461962014
2023/02/26 21:16:14 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-26_13_16_14-8777180321461962014?project=apache-beam-testing
2023/02/26 21:16:14 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-26_13_16_14-8777180321461962014
2023/02/26 21:16:14 Job state: JOB_STATE_PENDING ...
2023/02/26 21:16:44 Job still running ...
2023/02/26 21:17:15 Job still running ...
2023/02/26 21:17:45 Job still running ...
2023/02/26 21:18:15 Job still running ...
2023/02/26 21:18:45 Job still running ...
2023/02/26 21:19:15 Job still running ...
2023/02/26 21:19:45 Job still running ...
2023/02/26 21:20:15 Job still running ...
2023/02/26 21:20:45 Job still running ...
2023/02/26 21:21:15 Job still running ...
2023/02/26 21:21:45 Job still running ...
2023/02/26 21:22:15 Job still running ...
2023/02/26 21:22:45 Job still running ...
2023/02/26 21:23:15 Job still running ...
2023/02/26 21:23:45 Job still running ...
2023/02/26 21:24:15 Job still running ...
2023/02/26 21:24:45 Job still running ...
2023/02/26 21:25:15 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-26_13_16_14-8777180321461962014 failed
--- FAIL: TestXLang_Partition (579.75s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3202.325s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677443546539410311
--- FAIL: TestBigQueryIO_BasicWriteRead (4.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@hkFqwNiBli"  is_bounded:BOUNDED  windowing_strategy_id:"w0@hkFqwNiBli"}}  windowing_strategies:{key:"w0@hkFqwNiBli"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@hkFqwNiBli"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@hkFqwNiBli"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@hkFqwNiBli"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677443546539410311\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"hkFqwNiBli"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46491 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@hkFqwNiBli"  is_bounded:BOUNDED  windowing_strategy_id:"w0@hkFqwNiBli"}}  windowing_strategies:{key:"w0@hkFqwNiBli"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@hkFqwNiBli"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@hkFqwNiBli"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@hkFqwNiBli"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677443546539410311\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"hkFqwNiBli"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 30 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000029800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000029800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000592640?, 0xc0005aa000?}, {0x1138176, 0x39}, {0xc0005b40c0?, 0xa9cba0?, 0x1?}, {0xc000042d60, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005925e0?, 0xc0005aa000?}, {0xc00004c540, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d60, 0xf}, {0xc00004c540, 0x52}, {0xeba5c0, 0xc0001363d8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000493520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000493520, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.571s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:791aa7e5dc747ccf06d4b49008f9c1dde1b59187f5464aa2390043c8552566ea
Deleted: sha256:5b8c96b23a9a79737dfe70e43400b0373064be1fea3dd9e332d43bbd2d822bef
Deleted: sha256:eb813af614897766fcb51331b00f0de1cda854d755ab73d74ce0b14bc0465345
Deleted: sha256:1a4c25cfa41ffc05aa6f684e94a93ac98895ff66ef7f72fc50fcb3e82e389246
Deleted: sha256:5521d221c888d88426535b1ea29dccbf71d2291713c6672e8a54ca996fdba4a2
Deleted: sha256:99f8b5c319b527139ac639da99cdd07c8410e33bb829ac6cdb7bf3c64087d003
Deleted: sha256:1e784afd344455b6f98d65fac0239d62f8c56534dff63c1cc4a1ba551a395693
Deleted: sha256:17130fde18e197213fa4049fba0ec2cb862302e020b72f7b50a42d5274109e93
Deleted: sha256:2390e82a9ac5e141c27b8d2fb6d21d6adb126f45677ffa87adb6c270ae7bc525
Deleted: sha256:264c9012e8380160878ff836349cb64138575cf64571282609022941cd960ddb
Deleted: sha256:14a7017e4a09630e9401d7a52373ca26038e2cfd5e3b269cd5e0dcacbe62198f
Deleted: sha256:87474545e6cb24a53aa93548a365f8db2c170f919a32abde16754c741125a5eb
Deleted: sha256:641a64870d31a44e32bf9f97148f34d4a86fad39067aea38bcc539f437908220
Deleted: sha256:500c94d4e23d4385f7756b0aebb7a830f5113e4ab54f16e0759c92a82dc14983
Deleted: sha256:b4d03860092c98fbbce485a1e65a810d187e086ad069a447f0799cffd2c145f8
Deleted: sha256:c1b4dd99e35ef2fccf0264842a71b51b40f3c7b5a3802ce636b9699910861023
Deleted: sha256:888d7537450cc7aaa0eefc1f56ccdb858b1cb35e0e76ce7b5a413b6536987536
Deleted: sha256:ac6dcee7c336a5ce5521afed0a38dcde756197b6f2347af093e96124934d3267
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:791aa7e5dc747ccf06d4b49008f9c1dde1b59187f5464aa2390043c8552566ea
  Associated tags:
 - 20230226-203150
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-203150].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:791aa7e5dc747ccf06d4b49008f9c1dde1b59187f5464aa2390043c8552566ea].
$ rm -rf /tmp/tmp.j6ZjiT9uhc
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e894481710eacf42e8d3593ec779fd83cd25a3cf63f9147686335d3f5e5b38f4].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92495570d9414d1e897fab0013863027cfc759a84828da905f06ec5ea981da6c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1363860.
Stopping expansion service pid: 1363861.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 43s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1337

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1337/display/redirect>

Changes:


------------------------------------------
[...truncated 1020.14 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-143133",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226142037",
            "environmentId": "oZCfINBziqbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-143133"
      }
    ]
  },
  "name": "go-testxlang_partition-110",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/26 15:15:33 Submitted job: 2023-02-26_07_15_33-14292297810418415494
2023/02/26 15:15:33 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-26_07_15_33-14292297810418415494?project=apache-beam-testing
2023/02/26 15:15:33 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-26_07_15_33-14292297810418415494
2023/02/26 15:15:33 Job state: JOB_STATE_PENDING ...
2023/02/26 15:16:03 Job still running ...
2023/02/26 15:16:33 Job still running ...
2023/02/26 15:17:03 Job still running ...
2023/02/26 15:17:33 Job still running ...
2023/02/26 15:18:04 Job still running ...
2023/02/26 15:18:34 Job still running ...
2023/02/26 15:19:04 Job still running ...
2023/02/26 15:19:34 Job still running ...
2023/02/26 15:20:04 Job still running ...
2023/02/26 15:20:34 Job still running ...
2023/02/26 15:21:04 Job still running ...
2023/02/26 15:21:34 Job still running ...
2023/02/26 15:22:04 Job still running ...
2023/02/26 15:22:34 Job still running ...
2023/02/26 15:23:04 Job still running ...
2023/02/26 15:23:34 Job still running ...
2023/02/26 15:24:04 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-26_07_15_33-14292297810418415494 failed
--- FAIL: TestXLang_Partition (550.58s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3150.693s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677421927491768756
--- FAIL: TestBigQueryIO_BasicWriteRead (4.19s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41459 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@vbFWQPwzAa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@vbFWQPwzAa"}}  windowing_strategies:{key:"w0@vbFWQPwzAa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@vbFWQPwzAa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@vbFWQPwzAa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@vbFWQPwzAa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677421927491768756\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"vbFWQPwzAa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41459 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@vbFWQPwzAa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@vbFWQPwzAa"}}  windowing_strategies:{key:"w0@vbFWQPwzAa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@vbFWQPwzAa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@vbFWQPwzAa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@vbFWQPwzAa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677421927491768756\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"vbFWQPwzAa"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00048cec0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00048cec0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001167c0?, 0xc0000b8280?}, {0x1138176, 0x39}, {0xc0000ee180?, 0xa9cba0?, 0x1?}, {0xc00048bb10, 0xf}, 0xc0001a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000116760?, 0xc0000b8280?}, {0xc00004cd80, 0x52}, {0x1?}, {0xc0001a9ea8, 0x2, 0xe792c0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048bb10, 0xf}, {0xc00004cd80, 0x52}, {0xeba5c0, 0xc0003fc138})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a9ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a9ba0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.232s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5a2b55b06a0ca89945c4301d5e28447c9089e1c260f4f9ec4c878d12b9ed9632
  Associated tags:
 - 20230226-143133
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-143133
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-143133].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5a2b55b06a0ca89945c4301d5e28447c9089e1c260f4f9ec4c878d12b9ed9632].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226142037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0bee3e80b4003fbfe4325dc8d84b047b14659ab27e3cb1721d05ab692216f9f0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226142037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0bee3e80b4003fbfe4325dc8d84b047b14659ab27e3cb1721d05ab692216f9f0])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0bee3e80b4003fbfe4325dc8d84b047b14659ab27e3cb1721d05ab692216f9f0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0bee3e80b4003fbfe4325dc8d84b047b14659ab27e3cb1721d05ab692216f9f0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226142037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d175f88f2f5d77696890f3a1a40329992fe1aacd3dbf144b571500cee596794b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226142037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d175f88f2f5d77696890f3a1a40329992fe1aacd3dbf144b571500cee596794b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d175f88f2f5d77696890f3a1a40329992fe1aacd3dbf144b571500cee596794b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d175f88f2f5d77696890f3a1a40329992fe1aacd3dbf144b571500cee596794b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 22s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1336

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1336/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-083154",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226082038",
            "environmentId": "IIjiLwuVxCbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-083154"
      }
    ]
  },
  "name": "go-testxlang_partition-210",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/26 09:17:29 Submitted job: 2023-02-26_01_17_28-13362527664446641741
2023/02/26 09:17:29 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-26_01_17_28-13362527664446641741?project=apache-beam-testing
2023/02/26 09:17:29 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-26_01_17_28-13362527664446641741
2023/02/26 09:17:29 Job state: JOB_STATE_PENDING ...
2023/02/26 09:17:59 Job still running ...
2023/02/26 09:18:29 Job still running ...
2023/02/26 09:18:59 Job still running ...
2023/02/26 09:19:29 Job still running ...
2023/02/26 09:19:59 Job still running ...
2023/02/26 09:20:29 Job still running ...
2023/02/26 09:20:59 Job still running ...
2023/02/26 09:21:29 Job still running ...
2023/02/26 09:21:59 Job still running ...
2023/02/26 09:22:29 Job still running ...
2023/02/26 09:22:59 Job still running ...
2023/02/26 09:23:30 Job still running ...
2023/02/26 09:24:00 Job still running ...
2023/02/26 09:24:30 Job still running ...
2023/02/26 09:25:00 Job still running ...
2023/02/26 09:25:30 Job still running ...
2023/02/26 09:26:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-26_01_17_28-13362527664446641741 failed
--- FAIL: TestXLang_Partition (550.27s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3241.117s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677400352479852969
--- FAIL: TestBigQueryIO_BasicWriteRead (4.42s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43519 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@trQAHdGaqZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@trQAHdGaqZ"}}  windowing_strategies:{key:"w0@trQAHdGaqZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@trQAHdGaqZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@trQAHdGaqZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@trQAHdGaqZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677400352479852969\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"trQAHdGaqZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43519 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@trQAHdGaqZ"  is_bounded:BOUNDED  windowing_strategy_id:"w0@trQAHdGaqZ"}}  windowing_strategies:{key:"w0@trQAHdGaqZ"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@trQAHdGaqZ"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@trQAHdGaqZ"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@trQAHdGaqZ"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677400352479852969\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"trQAHdGaqZ"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 54 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00061c840})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00061c840})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004aabe0?, 0xc000117a40?}, {0x1138176, 0x39}, {0xc00015e0c0?, 0xa9cba0?, 0x1?}, {0xc00048ac20, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004aab80?, 0xc000117a40?}, {0xc0004b6300, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7f84f47377f0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ac20, 0xf}, {0xc0004b6300, 0x52}, {0xeba5c0, 0xc00048bf30})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000339d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000339d40, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.454s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c73635658d0fb04ca958b527248b86e096f721606706773b01643529faef1fcb
  Associated tags:
 - 20230226-083154
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-083154
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-083154].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c73635658d0fb04ca958b527248b86e096f721606706773b01643529faef1fcb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf90f36f0d00628cb7ddc8d6184888db4c4f52ec8bd0934de72c76b0d1080d5b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf90f36f0d00628cb7ddc8d6184888db4c4f52ec8bd0934de72c76b0d1080d5b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf90f36f0d00628cb7ddc8d6184888db4c4f52ec8bd0934de72c76b0d1080d5b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cf90f36f0d00628cb7ddc8d6184888db4c4f52ec8bd0934de72c76b0d1080d5b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226082038]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423d49c8273ad917795bd60cad85d43a5bab8b72cd28668539f0bcb9a04d922c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226082038] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423d49c8273ad917795bd60cad85d43a5bab8b72cd28668539f0bcb9a04d922c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423d49c8273ad917795bd60cad85d43a5bab8b72cd28668539f0bcb9a04d922c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:423d49c8273ad917795bd60cad85d43a5bab8b72cd28668539f0bcb9a04d922c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 17s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1335

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1335/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226022040",
            "environmentId": "sFcjwoVzJAbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144"
      }
    ]
  },
  "name": "go-testxlang_partition-631",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/26 03:16:11 Submitted job: 2023-02-25_19_16_10-5830925582430866727
2023/02/26 03:16:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-25_19_16_10-5830925582430866727?project=apache-beam-testing
2023/02/26 03:16:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-25_19_16_10-5830925582430866727
2023/02/26 03:16:11 Job state: JOB_STATE_PENDING ...
2023/02/26 03:16:41 Job still running ...
2023/02/26 03:17:11 Job still running ...
2023/02/26 03:17:41 Job still running ...
2023/02/26 03:18:11 Job still running ...
2023/02/26 03:18:41 Job still running ...
2023/02/26 03:19:11 Job still running ...
2023/02/26 03:19:41 Job still running ...
2023/02/26 03:20:11 Job still running ...
2023/02/26 03:20:41 Job still running ...
2023/02/26 03:21:11 Job still running ...
2023/02/26 03:21:41 Job still running ...
2023/02/26 03:22:11 Job still running ...
2023/02/26 03:22:41 Job still running ...
2023/02/26 03:23:11 Job still running ...
2023/02/26 03:23:41 Job still running ...
2023/02/26 03:24:12 Job still running ...
2023/02/26 03:24:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-25_19_16_10-5830925582430866727 failed
--- FAIL: TestXLang_Partition (550.49s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3175.545s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677378740165445441
--- FAIL: TestBigQueryIO_BasicWriteRead (4.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35151 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@cKcPGmkLDO"  is_bounded:BOUNDED  windowing_strategy_id:"w0@cKcPGmkLDO"}}  windowing_strategies:{key:"w0@cKcPGmkLDO"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@cKcPGmkLDO"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@cKcPGmkLDO"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@cKcPGmkLDO"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677378740165445441\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"cKcPGmkLDO"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35151 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@cKcPGmkLDO"  is_bounded:BOUNDED  windowing_strategy_id:"w0@cKcPGmkLDO"}}  windowing_strategies:{key:"w0@cKcPGmkLDO"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@cKcPGmkLDO"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@cKcPGmkLDO"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@cKcPGmkLDO"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677378740165445441\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"cKcPGmkLDO"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0005f7000})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0005f7000})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000710860?, 0xc000114280?}, {0x1138176, 0x39}, {0xc00015c180?, 0xa9cba0?, 0x1?}, {0xc0000433b0, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000710800?, 0xc000114280?}, {0xc00004c660, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7feb880d46d8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0000433b0, 0xf}, {0xc00004c660, 0x52}, {0xeba5c0, 0xc0003f4140})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582b60, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.243s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f24eb0c225d238bf0a03a48b822f080b7e94dc08e88ffacc98f09f59fe90a927
Deleted: sha256:7ea1765a5ca8f2d9ba5bfc120bb356f4a13c4a30af1cc234b1a48a113820947d
Deleted: sha256:9eaa359ddb4185f862e683a2fae4ba745fce194b42a1197b8e2d821e24162917
Deleted: sha256:7cc7cc095795c8592c97e4854c0a0fd937cf393999724cfdf7e00adc89d6ac97
Deleted: sha256:44ce18a423e947bd6143776cffc26293ba52bc051818f719fd1965b1d99130d5
Deleted: sha256:7d0793002ada3045d320f8d36b68a7e76bd43aacc6a19caf7e790e2ccdfa0258
Deleted: sha256:0e54371273da8bc7ea757b2409aea1f40f3beb2af730bf753f4b4835d9105ab8
Deleted: sha256:a463d811e8cb4262a949b50f9ad4e19c9314a8e1a0d13f6562200f6156779a91
Deleted: sha256:b54cbf40e207bb44b5c0733eb5a2f570fa91501a0267638544c04d554be6dba8
Deleted: sha256:fa753175cd84ba1210fb39fadd7a5a6b009c19e7c9a0f30d08623649cf901adc
Deleted: sha256:5ea48fa607beb132feff3f9e61cba9f8bd9f35f6f2b2a9d8fea0d79d3edac8a0
Deleted: sha256:9bf0113149fe3010dd8e0d3fd807819f60d58b67ac4a9d26837a4c4c681aabf2
Deleted: sha256:465f7c5ff4cfaef5b4443c3c10d04d23bd28d2eecb94230e4a4e06522385ccbe
Deleted: sha256:d30a86e9dfcc634770686ac3bbd239ae057000aff423880584bf3f58cbd4542e
Deleted: sha256:7ba4c944bc2f760f0df3f64a6ea58b2b32cc2a9d66fa4cd8eeb11eda036f7ac2
Deleted: sha256:0f61fb779236748df5c96468aa3b4e6db799fc85e2a4c1b1df418956cc3d24b8
Deleted: sha256:e0de893e918121daf823c987244a934654dd1bf8a7ae96307973d22f27671bf6
Deleted: sha256:26f16b1ef9bde068f6196e58957dafd53bcba4db2bca6fb3e125c495d649b5bf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f24eb0c225d238bf0a03a48b822f080b7e94dc08e88ffacc98f09f59fe90a927
  Associated tags:
 - 20230226-023144
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230226-023144].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f24eb0c225d238bf0a03a48b822f080b7e94dc08e88ffacc98f09f59fe90a927].
$ rm -rf /tmp/tmp.HySSVOPi6I
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226022040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230226022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:574b22595466a65fd2293496c506770d5128825fe408422bec6f2d3ef02916ff].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226022040
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226022040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230226022040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e702872c76d45d528cc8ed5b225061b490979ab6623dedf2c48878367410c4ee].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 927827.
Stopping expansion service pid: 927828.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 59s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1334

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1334/display/redirect>

Changes:


------------------------------------------
[...truncated 1020.84 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225202030",
            "environmentId": "IROftJwEtdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143"
      }
    ]
  },
  "name": "go-testxlang_partition-193",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/25 21:16:46 Submitted job: 2023-02-25_13_16_46-11565331478085944616
2023/02/25 21:16:46 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-25_13_16_46-11565331478085944616?project=apache-beam-testing
2023/02/25 21:16:46 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-25_13_16_46-11565331478085944616
2023/02/25 21:16:46 Job state: JOB_STATE_PENDING ...
2023/02/25 21:17:16 Job still running ...
2023/02/25 21:17:46 Job still running ...
2023/02/25 21:18:16 Job still running ...
2023/02/25 21:18:46 Job still running ...
2023/02/25 21:19:16 Job still running ...
2023/02/25 21:19:47 Job still running ...
2023/02/25 21:20:17 Job still running ...
2023/02/25 21:20:47 Job still running ...
2023/02/25 21:21:17 Job still running ...
2023/02/25 21:21:47 Job still running ...
2023/02/25 21:22:17 Job still running ...
2023/02/25 21:22:47 Job still running ...
2023/02/25 21:23:17 Job still running ...
2023/02/25 21:23:47 Job still running ...
2023/02/25 21:24:17 Job still running ...
2023/02/25 21:24:47 Job still running ...
2023/02/25 21:25:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-25_13_16_46-11565331478085944616 failed
--- FAIL: TestXLang_Partition (550.12s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3210.942s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677357139781330010
--- FAIL: TestBigQueryIO_BasicWriteRead (4.35s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39335 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SROOimxTUm"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SROOimxTUm"}}  windowing_strategies:{key:"w0@SROOimxTUm"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SROOimxTUm"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SROOimxTUm"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SROOimxTUm"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677357139781330010\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SROOimxTUm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39335 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@SROOimxTUm"  is_bounded:BOUNDED  windowing_strategy_id:"w0@SROOimxTUm"}}  windowing_strategies:{key:"w0@SROOimxTUm"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@SROOimxTUm"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@SROOimxTUm"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@SROOimxTUm"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677357139781330010\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"SROOimxTUm"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc000113340})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc000113340})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7880?, 0xc000133680?}, {0x1138176, 0x39}, {0xc000142000?, 0xa9cba0?, 0x1?}, {0xc0003fcd80, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7820?, 0xc000133680?}, {0xc000548300, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7f122b56f448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fcd80, 0xf}, {0xc000548300, 0x52}, {0xeba5c0, 0xc0000422b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.390s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:45e27e9d3a0d19be199d9dcdc6f3c8b2e6164ba75cab16362ebf459ec9ed02e8
Deleted: sha256:43bc090d0639b8ac8cb794fb7ab2ac5a379d68aeba8e581b176a5e9e2f477cab
Deleted: sha256:d0e66c5e1f175be6fd447266781bd4833d75117dbc0eaa1370395fd2039ed7e3
Deleted: sha256:ccc9fcff016ef506521a3de8152a77dcb37ac21e5acc42a3c15b1f88067df5a5
Deleted: sha256:8415e71b38dde8cbc09fb3f90d10c512f5e3f39a46a45031b0c6f7f570f8f3e7
Deleted: sha256:412ea4b5a3f19050aedc2f4ad943ca1fd0b5e18b223ce7a230a5a9efb92b51cb
Deleted: sha256:2cbdea00755d7ef3189b1b11410710fe96ebf4538e8b424b78f5a1f79eb68a8e
Deleted: sha256:ef9cc8f45ee7943606297645961a86412e4d10b71df2efc5a989711302d41e1e
Deleted: sha256:7f4d0e5beb86a79520a9ab94a0c7682c38e1b2160c4395509171922236badc17
Deleted: sha256:ed156fe3189ec9bc16ebffc968af2a907b0b3a2efc6f61d2c13d670e0361a3a1
Deleted: sha256:b510269a1f47fb64be1eca53d6301494526288c2cfb184344a8d33908ace0d6e
Deleted: sha256:78b9ec0a8db2c7006df3279087b5d0e9b1fc6c64851227d072d832abfb53dbd8
Deleted: sha256:8a0c8cff021ac1730f30309b9415494464cf1799edd9b4d2b654a47f0f57d010
Deleted: sha256:d14f70cbd10e45680f2066e9318bf691d4b131168ec1ea1e7525663f26575d52
Deleted: sha256:da352ab04da13ff2e589e6f99db3016e9afc879e01f114192a3c19df58414ee4
Deleted: sha256:896bb3779f13644b855ba9efbaf69961f167dd539e190df2994fa9d00afece12
Deleted: sha256:9da7df8af821d990e239e010d221143dc2d0bef66dc0522ff9bc0c41c0193c88
Deleted: sha256:a92c471fbcb16b7181ff8f0fe48971bb098e36d469df647922d57ab3ecefda58
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:45e27e9d3a0d19be199d9dcdc6f3c8b2e6164ba75cab16362ebf459ec9ed02e8
  Associated tags:
 - 20230225-203143
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-203143].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:45e27e9d3a0d19be199d9dcdc6f3c8b2e6164ba75cab16362ebf459ec9ed02e8].
$ rm -rf /tmp/tmp.ptdpQfXgom
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8bb8a6cd66d04bfa89b3f5c75b9d35af40f22c2b173ef47aceaff155a6c40e00].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225202030
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225202030]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225202030] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2aedf4888f29401409af56ebec951b97a4d7fd17a4fef3a5e6de4f4160103261].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 825926.
Stopping expansion service pid: 825927.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 45s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1333

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1333/display/redirect>

Changes:


------------------------------------------
[...truncated 1020.61 KB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-143139",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225142036",
            "environmentId": "GsXwytKZzabeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-143139"
      }
    ]
  },
  "name": "go-testxlang_partition-749",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/25 15:14:42 Submitted job: 2023-02-25_07_14_42-17295565077595945707
2023/02/25 15:14:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-25_07_14_42-17295565077595945707?project=apache-beam-testing
2023/02/25 15:14:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-25_07_14_42-17295565077595945707
2023/02/25 15:14:42 Job state: JOB_STATE_PENDING ...
2023/02/25 15:15:12 Job still running ...
2023/02/25 15:15:42 Job still running ...
2023/02/25 15:16:12 Job still running ...
2023/02/25 15:16:43 Job still running ...
2023/02/25 15:17:13 Job still running ...
2023/02/25 15:17:43 Job still running ...
2023/02/25 15:18:13 Job still running ...
2023/02/25 15:18:43 Job still running ...
2023/02/25 15:19:13 Job still running ...
2023/02/25 15:19:43 Job still running ...
2023/02/25 15:20:13 Job still running ...
2023/02/25 15:20:43 Job still running ...
2023/02/25 15:21:13 Job still running ...
2023/02/25 15:21:43 Job still running ...
2023/02/25 15:22:13 Job still running ...
2023/02/25 15:22:43 Job still running ...
2023/02/25 15:23:13 Job still running ...
2023/02/25 15:23:43 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-25_07_14_42-17295565077595945707 failed
--- FAIL: TestXLang_Partition (580.70s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3122.704s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677335534603357289
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34349 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@LjDiCKYtgp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@LjDiCKYtgp"}}  windowing_strategies:{key:"w0@LjDiCKYtgp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@LjDiCKYtgp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@LjDiCKYtgp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@LjDiCKYtgp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677335534603357289\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"LjDiCKYtgp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34349 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@LjDiCKYtgp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@LjDiCKYtgp"}}  windowing_strategies:{key:"w0@LjDiCKYtgp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@LjDiCKYtgp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@LjDiCKYtgp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@LjDiCKYtgp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677335534603357289\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"LjDiCKYtgp"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc0004b2980})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc0004b2980})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004886c0?, 0xc0000bc0a0?}, {0x1138176, 0x39}, {0xc00046c0c0?, 0xa9cba0?, 0x1?}, {0xc00065b4d0, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488660?, 0xc0000bc0a0?}, {0xc00010e900, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f80f1530448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00065b4d0, 0xf}, {0xc00010e900, 0x52}, {0xeba5c0, 0xc000042300})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000642ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000642ea0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.369s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fc54e75d5a826f659fe479dd8de60ad48be78def280235b11b574b4c2d48ea54
  Associated tags:
 - 20230225-143139
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-143139
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-143139].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:fc54e75d5a826f659fe479dd8de60ad48be78def280235b11b574b4c2d48ea54].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225142036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0192f6f1a07e0389ec0e375f14948b18912738517abfeb3c4ab0129b14f0a931]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225142036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0192f6f1a07e0389ec0e375f14948b18912738517abfeb3c4ab0129b14f0a931])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0192f6f1a07e0389ec0e375f14948b18912738517abfeb3c4ab0129b14f0a931
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0192f6f1a07e0389ec0e375f14948b18912738517abfeb3c4ab0129b14f0a931].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225142036]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5ea91234ae270bfe2a76fd84c38438c890e22c173cb0807683a729e6bb8169ff]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225142036] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5ea91234ae270bfe2a76fd84c38438c890e22c173cb0807683a729e6bb8169ff])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5ea91234ae270bfe2a76fd84c38438c890e22c173cb0807683a729e6bb8169ff
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5ea91234ae270bfe2a76fd84c38438c890e22c173cb0807683a729e6bb8169ff].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 6s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2nufrluvqhc2o

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1332

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1332/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225082026",
            "environmentId": "EHkNrmTOGdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131"
      }
    ]
  },
  "name": "go-testxlang_partition-657",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/25 09:16:29 Submitted job: 2023-02-25_01_16_29-15969166680199757939
2023/02/25 09:16:29 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-25_01_16_29-15969166680199757939?project=apache-beam-testing
2023/02/25 09:16:29 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-25_01_16_29-15969166680199757939
2023/02/25 09:16:30 Job state: JOB_STATE_PENDING ...
2023/02/25 09:17:00 Job still running ...
2023/02/25 09:17:30 Job still running ...
2023/02/25 09:18:00 Job still running ...
2023/02/25 09:18:30 Job still running ...
2023/02/25 09:19:00 Job still running ...
2023/02/25 09:19:30 Job still running ...
2023/02/25 09:20:00 Job still running ...
2023/02/25 09:20:30 Job still running ...
2023/02/25 09:21:00 Job still running ...
2023/02/25 09:21:30 Job still running ...
2023/02/25 09:22:00 Job still running ...
2023/02/25 09:22:30 Job still running ...
2023/02/25 09:23:00 Job still running ...
2023/02/25 09:23:30 Job still running ...
2023/02/25 09:24:00 Job still running ...
2023/02/25 09:24:30 Job still running ...
2023/02/25 09:25:00 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-25_01_16_29-15969166680199757939 failed
--- FAIL: TestXLang_Partition (550.74s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3206.024s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677313928171406585
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45923 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@Vrpcpiywje"  is_bounded:BOUNDED  windowing_strategy_id:"w0@Vrpcpiywje"}}  windowing_strategies:{key:"w0@Vrpcpiywje"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@Vrpcpiywje"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@Vrpcpiywje"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@Vrpcpiywje"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677313928171406585\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"Vrpcpiywje"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45923 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@Vrpcpiywje"  is_bounded:BOUNDED  windowing_strategy_id:"w0@Vrpcpiywje"}}  windowing_strategies:{key:"w0@Vrpcpiywje"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@Vrpcpiywje"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@Vrpcpiywje"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@Vrpcpiywje"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677313928171406585\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"Vrpcpiywje"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00065a400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00065a400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010e8a0?, 0xc0005a8000?}, {0x1138176, 0x39}, {0xc0000f0180?, 0xa9cba0?, 0x1?}, {0xc0003fade0, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e840?, 0xc0005a8000?}, {0xc0005445a0, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7fe2306d9c40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fade0, 0xf}, {0xc0005445a0, 0x52}, {0xeba5c0, 0xc000122210})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103ba0, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.433s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7cd849d7d655bcdb87bb8b026b9a6a6a02bb47c34b50ceca9f77a6f3aa7c0cc6
Deleted: sha256:b913295d166485f8cb726d9ca1dade0a9166ef548929f9f1bd7283ecbff098fe
Deleted: sha256:4b3c84e7324281265c283949e5ca90f06bd95b8b5c06530cacfc4113b01e28da
Deleted: sha256:b231afbde8c6a37105f2c2b27891d853006700b015b03c60a862e5523fffa7e4
Deleted: sha256:9c365221150a4f7242174e0da19fae4b0a3cbc4b259fa2ddb8d682fb83b89e4f
Deleted: sha256:f72310438d31af99740ef729e21fa0d777098781e8ea9a1478f63238b680d18d
Deleted: sha256:ac9727979899009f1c67b56fc140785fe3fbc422b3548f66b2f2287949cb59e6
Deleted: sha256:195762848f590ebd2ccce8727727898d2be8170f6cf9822e44edf4b923c1535b
Deleted: sha256:a3d469e85cd4825be7d3520003e57a8ee8a91526592689111ec3733d018cc2da
Deleted: sha256:9578a63bfe147d2cbb49088de2e096e5c58b9985bc8cae1bdd695938bcde2421
Deleted: sha256:711a856124f46f68a07e27b42d0eb7e0dc2533c9f0d9205e59994fe760be798e
Deleted: sha256:a03e1a16f8b4dc71688891ea7b8da9d9fcd5a59fa589ca147441b5a95e1b8cb9
Deleted: sha256:39aa7c781cd93d85e1b14acf4ff75f5f0743f4e30aebdabbc95c68b7de34c1c1
Deleted: sha256:8a1cb826a26e65f78088d29a95597fb48e3df07aac82349b390a5aff3657653d
Deleted: sha256:73c41b1103e5868524ac8ac592d1e4625c70bdef0ddeb1417beaa966b32afa92
Deleted: sha256:ec13371b2888cea382025d3e1707f31e92959d3eac65645ca4a47eb1c33022a6
Deleted: sha256:469e3cbe1d5e03c361c766622b98009d171f0b0634a6a5da086ce10aa02b96d9
Deleted: sha256:812c9102f9d407793ce7c35dcd86aefaffd561b1efc2c731b1d02a71feffe41b
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7cd849d7d655bcdb87bb8b026b9a6a6a02bb47c34b50ceca9f77a6f3aa7c0cc6
  Associated tags:
 - 20230225-083131
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-083131].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7cd849d7d655bcdb87bb8b026b9a6a6a02bb47c34b50ceca9f77a6f3aa7c0cc6].
$ rm -rf /tmp/tmp.sLFgREQ4Bd
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225082026
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225082026]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225082026] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:cc9e83c0fc4ceecdc497bf163926b3a93c3c881dc79ed6864eff70d4adea1148].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225082026
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225082026]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225082026] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:febbb86240a06fa6c4d0729f13b34e26f016b70d7e949133ce8c6a9d8b7a26d7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 615681.
Stopping expansion service pid: 615682.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 30s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1331

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1331/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158"
      }
    ]
  },
  "name": "go-testxlang_partition-151",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/25 03:16:57 Submitted job: 2023-02-24_19_16_56-11521018991568117690
2023/02/25 03:16:57 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-24_19_16_56-11521018991568117690?project=apache-beam-testing
2023/02/25 03:16:57 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-24_19_16_56-11521018991568117690
2023/02/25 03:16:57 Job state: JOB_STATE_PENDING ...
2023/02/25 03:17:27 Job still running ...
2023/02/25 03:17:57 Job still running ...
2023/02/25 03:18:27 Job still running ...
2023/02/25 03:18:57 Job still running ...
2023/02/25 03:19:27 Job still running ...
2023/02/25 03:19:57 Job still running ...
2023/02/25 03:20:27 Job still running ...
2023/02/25 03:20:57 Job still running ...
2023/02/25 03:21:28 Job still running ...
2023/02/25 03:21:58 Job still running ...
2023/02/25 03:22:28 Job still running ...
2023/02/25 03:22:58 Job still running ...
2023/02/25 03:23:28 Job still running ...
2023/02/25 03:23:58 Job still running ...
2023/02/25 03:24:28 Job still running ...
2023/02/25 03:24:58 Job still running ...
2023/02/25 03:25:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-24_19_16_56-11521018991568117690 failed
--- FAIL: TestXLang_Partition (550.00s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3206.320s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677292355323572625
--- FAIL: TestBigQueryIO_BasicWriteRead (4.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36881 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XHPIiqUkcf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XHPIiqUkcf"}}  windowing_strategies:{key:"w0@XHPIiqUkcf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XHPIiqUkcf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XHPIiqUkcf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XHPIiqUkcf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677292355323572625\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XHPIiqUkcf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36881 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XHPIiqUkcf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XHPIiqUkcf"}}  windowing_strategies:{key:"w0@XHPIiqUkcf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XHPIiqUkcf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XHPIiqUkcf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XHPIiqUkcf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677292355323572625\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XHPIiqUkcf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00025b7c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00025b7c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004c6d00?, 0xc0000b9a40?}, {0x1138176, 0x39}, {0xc0000ee0c0?, 0xa9cba0?, 0x1?}, {0xc00064ec50, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004c6ca0?, 0xc0000b9a40?}, {0xc0004d8300, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7ff84542aa78?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00064ec50, 0xf}, {0xc0004d8300, 0x52}, {0xeba5c0, 0xc00064ff60})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000463040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000463040, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.417s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca0ddd3f8645dbcc4a1519e36a76313da900106ef35c102365f76c0ada3536bc
Deleted: sha256:7349afecd3fe12d9dd789197e3c227774552e8205433eb18ea822a892e20144e
Deleted: sha256:c16aaaf4416dd526a04827753ca68ee7720bcd9f4950c655f20e1e1723340ef5
Deleted: sha256:bf13ec4b1b12073d839f1aa8716fc54f36f1640602f85dd835f5907b44741a56
Deleted: sha256:8c37c58febff81791c62d5ee4ed399f76c8ec98e156487daaf6d70023a1aad72
Deleted: sha256:c34e245447e332048681cbfecb2675ddeb4e09dabc6d41057dd202aa9ff8d3d5
Deleted: sha256:8cf3ec91cd6526516a1910ce8a302e1322172da23c4b404fbfbe5dedd9396ac6
Deleted: sha256:4b53c4cab19b49433455360bb87132daa745ed08cf5ea234aeb26d46fb9a394a
Deleted: sha256:06f8f1aea16ac104d240f793bcdbf8ca4347025ee8bd5b440c7592c3acaa7abe
Deleted: sha256:203629c07d27039e752bfca70c61a64d4bd0f3e6a5ee27d41f04c1ebc8d91c1f
Deleted: sha256:0da7f8b8d23010a46f7c5bebf89809cc03f60e0ec8107d201510c7dc6a37b157
Deleted: sha256:1aaa9bfcf63eb3e9e71b2de6a543737b368ae2c06429cc14551f4235c1d31785
Deleted: sha256:c0daa1a349995017f1a660e04d1d8cd51bcbe8b984de7ea976dfb5f303e55631
Deleted: sha256:5c13e1e27770c12d4f3f211859e19ce2f746622bf5e495f71e0338d1bf978c2d
Deleted: sha256:8160d75a08cc053576f4fa990503ac139135906bc02fbf65668def5149ab4c47
Deleted: sha256:96136eba473dfade6d6fc2be01940c9d175d2c7dc727bafc526f777f325aac92
Deleted: sha256:10fe4e0dbc19d6e633b2347fb1684982d94ee1b42c7caa1ac998f85b8286a2e4
Deleted: sha256:da2b92582adaf29197646cdb01f6c9417476db51b8e6f87ac282b20c7c67f2a7
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca0ddd3f8645dbcc4a1519e36a76313da900106ef35c102365f76c0ada3536bc
  Associated tags:
 - 20230225-023158
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230225-023158].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca0ddd3f8645dbcc4a1519e36a76313da900106ef35c102365f76c0ada3536bc].
$ rm -rf /tmp/tmp.6hu5CjKuTI
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225022037
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225022037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230225022037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbcd0ecd42939813a8e74f29bf5e3e8ae9d58f8699ecb655e2049d51909be99b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225022037
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225022037]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230225022037] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d99ff7de13553f440c5b86445aa632ad06209691f122b45ba8156d93634f81a6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 477774.
Stopping expansion service pid: 477775.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 47s
232 actionable tasks: 154 executed, 66 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1330

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1330/display/redirect?page=changes>

Changes:

[noreply] Bump google.golang.org/api from 0.109.0 to 0.110.0 in /sdks (#25619)


------------------------------------------
[...truncated 1022.45 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-203140",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224202029",
            "environmentId": "EtRvhrkGipbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-203140"
      }
    ]
  },
  "name": "go-testxlang_partition-461",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/24 21:17:17 Submitted job: 2023-02-24_13_17_16-16338839448074889467
2023/02/24 21:17:17 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-24_13_17_16-16338839448074889467?project=apache-beam-testing
2023/02/24 21:17:17 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-24_13_17_16-16338839448074889467
2023/02/24 21:17:17 Job state: JOB_STATE_PENDING ...
2023/02/24 21:17:47 Job still running ...
2023/02/24 21:18:17 Job still running ...
2023/02/24 21:18:47 Job still running ...
2023/02/24 21:19:17 Job still running ...
2023/02/24 21:19:47 Job still running ...
2023/02/24 21:20:17 Job still running ...
2023/02/24 21:20:47 Job still running ...
2023/02/24 21:21:17 Job still running ...
2023/02/24 21:21:47 Job still running ...
2023/02/24 21:22:17 Job still running ...
2023/02/24 21:22:47 Job still running ...
2023/02/24 21:23:17 Job still running ...
2023/02/24 21:23:48 Job still running ...
2023/02/24 21:24:18 Job still running ...
2023/02/24 21:24:48 Job still running ...
2023/02/24 21:25:18 Job still running ...
2023/02/24 21:25:48 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-24_13_17_16-16338839448074889467 failed
--- FAIL: TestXLang_Partition (550.84s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3239.247s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677270747832899771
--- FAIL: TestBigQueryIO_BasicWriteRead (5.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44573 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZvuzFvJwVj"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZvuzFvJwVj"}}  windowing_strategies:{key:"w0@ZvuzFvJwVj"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZvuzFvJwVj"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZvuzFvJwVj"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZvuzFvJwVj"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677270747832899771\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZvuzFvJwVj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44573 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZvuzFvJwVj"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZvuzFvJwVj"}}  windowing_strategies:{key:"w0@ZvuzFvJwVj"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZvuzFvJwVj"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZvuzFvJwVj"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZvuzFvJwVj"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677270747832899771\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZvuzFvJwVj"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6c7e0, 0xc00048eac0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6c7e0, 0xc00048eac0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048ae20?, 0xc000497680?}, {0x1138176, 0x39}, {0xc000130000?, 0xa9cba0?, 0x1?}, {0xc0005ab1a0, 0xf}, 0xc0006f1d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048adc0?, 0xc000497680?}, {0xc00068c300, 0x52}, {0x1?}, {0xc0006f1ea8, 0x2, 0x7f36096c0448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005ab1a0, 0xf}, {0xc00068c300, 0x52}, {0xeba5c0, 0xc000042e60})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a9380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a9380, 0x116a168)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.608s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2e8ae331fa853782727e6d74a66fc813f6cef21652e2cd3514bb52b9bbf8a67f
  Associated tags:
 - 20230224-203140
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-203140
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-203140].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2e8ae331fa853782727e6d74a66fc813f6cef21652e2cd3514bb52b9bbf8a67f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224202029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35726f06ef0119c3fcd7730bd60478a77f9e0e12732e5fc222863d2a0d1b3529]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224202029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35726f06ef0119c3fcd7730bd60478a77f9e0e12732e5fc222863d2a0d1b3529])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35726f06ef0119c3fcd7730bd60478a77f9e0e12732e5fc222863d2a0d1b3529
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:35726f06ef0119c3fcd7730bd60478a77f9e0e12732e5fc222863d2a0d1b3529].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224202029]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e4266c9445835fb9d7a9fc9b0acf37a0a3c9a07374b7cb1475f00dd0aa3dc6c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224202029] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e4266c9445835fb9d7a9fc9b0acf37a0a3c9a07374b7cb1475f00dd0aa3dc6c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e4266c9445835fb9d7a9fc9b0acf37a0a3c9a07374b7cb1475f00dd0aa3dc6c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e4266c9445835fb9d7a9fc9b0acf37a0a3c9a07374b7cb1475f00dd0aa3dc6c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 17s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1329

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1329/display/redirect>

Changes:


------------------------------------------
[...truncated 603.26 KB...]
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
11ea9f26f413: Preparing
95cee01e0ee9: Preparing
134fb2533446: Preparing
227ad791baa2: Preparing
a00b779bef84: Preparing
a2b89e5221bf: Preparing
9bf16e2bb96b: Preparing
898af79d80c8: Preparing
c41c22b9214f: Preparing
ae8769bdbab5: Preparing
cd78828a09e9: Preparing
71933f404ea7: Preparing
3f8c1ac71347: Preparing
5db1a6b09d79: Preparing
4568910c2995: Preparing
26eafd96cbc2: Preparing
28a3fbb997db: Preparing
17efc79ac0fe: Preparing
0b6859e9fff1: Preparing
11829b3be9c0: Preparing
dc8e1d8b53e9: Preparing
9d49e0bc68a4: Preparing
8e396a1aad50: Preparing
5db1a6b09d79: Waiting
4568910c2995: Waiting
26eafd96cbc2: Waiting
28a3fbb997db: Waiting
a2b89e5221bf: Waiting
17efc79ac0fe: Waiting
9bf16e2bb96b: Waiting
0b6859e9fff1: Waiting
898af79d80c8: Waiting
c41c22b9214f: Waiting
ae8769bdbab5: Waiting
cd78828a09e9: Waiting
71933f404ea7: Waiting
11829b3be9c0: Waiting
3f8c1ac71347: Waiting
dc8e1d8b53e9: Waiting
9d49e0bc68a4: Waiting
8e396a1aad50: Waiting
a00b779bef84: Pushed
227ad791baa2: Pushed
134fb2533446: Pushed
11ea9f26f413: Pushed
c41c22b9214f: Pushed
898af79d80c8: Pushed
95cee01e0ee9: Pushed
9bf16e2bb96b: Pushed
3f8c1ac71347: Pushed
5db1a6b09d79: Pushed
4568910c2995: Layer already exists
26eafd96cbc2: Layer already exists
28a3fbb997db: Layer already exists
17efc79ac0fe: Layer already exists
0b6859e9fff1: Layer already exists
11829b3be9c0: Layer already exists
cd78828a09e9: Pushed
dc8e1d8b53e9: Layer already exists
9d49e0bc68a4: Layer already exists
8e396a1aad50: Layer already exists
a2b89e5221bf: Pushed
ae8769bdbab5: Pushed
71933f404ea7: Pushed
20230224142040: digest: sha256:bd5bba4edb4f1752e4d05d5f67dd17bf8f6154f2f53709d57e02297bde79d319 size: 5156

> Task :runners:google-cloud-dataflow-java:setupXVR

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerSetup
Launching Java expansion service @ 34325
Launching Python expansion service @ 41581

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava
$ CURRENT_DIRECTORY=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/go/test
$ TESTS=./test/integration/... ./test/regression
$ RUNNER=portable
$ TIMEOUT=3h
$ SIMULTANEOUS=3
$ GCS_LOCATION=gs://temp-storage-for-end-to-end-tests
$ GCS_SUBFOLDER=test25998
$ PROJECT=apache-beam-testing
$ DATAFLOW_PROJECT=apache-beam-testing
$ REGION=us-central1
$ trap exit_background_processes SIGINT SIGTERM EXIT
$ key=--pipeline_opts
$ case --pipeline_opts in
$ PIPELINE_OPTS=--kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.47.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.47.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:34325
$ key=--runner
$ case --runner in
$ RUNNER=dataflow
$ key=--project
$ case --project in
$ PROJECT=apache-beam-testing
$ key=--dataflow_project
$ case --dataflow_project in
$ DATAFLOW_PROJECT=apache-beam-testing
$ key=--region
$ case --region in
$ REGION=us-central1
$ key=--tests
$ case --tests in
$ TESTS=./test/integration/xlang ./test/integration/io/xlang/...
$ key=--sdk_overrides
$ case --sdk_overrides in
$ SDK_OVERRIDES=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224142040
$ cd /home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src
$ test -d sdks/go/test
$ command -v docker
/usr/bin/docker
$ docker -v
Docker version 20.10.23, build 7155243
$ command -v gcloud
/usr/bin/gcloud
$ gcloud --version
Google Cloud SDK 406.0.0
alpha 2022.10.17
beta 2022.10.17
bq 2.0.79
bundled-python3-unix 3.9.12
core 2022.10.17
gcloud-crc32c 1.0.0
gsutil 5.14
$ TMPDIR=/tmp/tmp.7HXZb8v28x
$ gcloud_ver=406.0.0
$ TAG=20230224-143536
$ CONTAINER=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
Using container us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
$ ./gradlew :sdks:go:container:docker -Pdocker-repository-root=us.gcr.io/apache-beam-testing/jenkins -Pdocker-tag=20230224-143536
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.5.1/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy UP-TO-DATE
> Task :buildSrc:pluginDescriptors UP-TO-DATE
> Task :buildSrc:processResources UP-TO-DATE
> Task :buildSrc:classes UP-TO-DATE
> Task :buildSrc:jar UP-TO-DATE
> Task :buildSrc:assemble UP-TO-DATE
> Task :buildSrc:spotlessGroovy UP-TO-DATE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.6
GOCMD=/home/jenkins/go/bin/go1.19.6
go1.19.6: already downloaded in /home/jenkins/sdk/go1.19.6
> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean
> Task :sdks:go:container:goPrepare UP-TO-DATE

> Task :sdks:go:container:goBuild
/home/jenkins/go/bin/go1.19.6 build -o ./build/target/linux_amd64/boot boot.go boot_test.go

> Task :sdks:go:container:skipPullLicenses
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

BUILD SUCCESSFUL in 55s
16 actionable tasks: 5 executed, 11 up-to-date

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

$ docker images
$ grep 20230224-143536
us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk         20230224-143536   2938a3cd3064   2 seconds ago       150MB
$ gcloud docker -- push us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-143536
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk]
1c0f3803d761: Preparing
6fae674145c3: Preparing
bbb915ba9718: Preparing
d7d5745a5db5: Preparing
79f84237325e: Preparing
e04a2f36f96f: Preparing
62809fe7825d: Preparing
8e396a1aad50: Preparing
e04a2f36f96f: Waiting
62809fe7825d: Waiting
bbb915ba9718: Pushed
6fae674145c3: Pushed
d7d5745a5db5: Pushed
1c0f3803d761: Pushed
79f84237325e: Pushed
8e396a1aad50: Layer already exists
62809fe7825d: Pushed
e04a2f36f96f: Pushed
20230224-143536: digest: sha256:f1a21cc49dbfea7ede6e3650d4cc8d66fbd4dbf460679e864eb93fb64b8367d8 size: 1990
$ OVERRIDE=--sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224142040
$ cd sdks/go
>>> RUNNING dataflow integration tests with pipeline options:  -p 3 -timeout 3h --runner=dataflow --project=apache-beam-testing --region=us-central1 --environment_type=DOCKER --environment_config=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-143536 --staging_location=gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test1127 --temp_location=gs://temp-storage-for-end-to-end-tests/temp-validatesrunner-test/test1127 --endpoint= --sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224142040 --kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.47.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.47.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:34325
$ 
System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.3
go1.19.3: already downloaded in /home/jenkins/sdk/go1.19.3
/home/jenkins/go/bin/go1.19.3 test -v ./test/integration/xlang ./test/integration/io/xlang/... -p 3 -timeout 3h --runner=dataflow --project=apache-beam-testing --region=us-central1 --environment_type=DOCKER --environment_config=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-143536 --staging_location=gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test1127 --temp_location=gs://temp-storage-for-end-to-end-tests/temp-validatesrunner-test/test1127 --endpoint= --sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224142040 --kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.47.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.47.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:34325
FATAL: command execution failed
java.io.IOException: Backing channel 'apache-beam-jenkins-8' is disconnected.
	at hudson.remoting.RemoteInvocationHandler.channelOrFail(RemoteInvocationHandler.java:215)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:285)
	at com.sun.proxy.$Proxy141.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1215)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1207)
	at hudson.Launcher$ProcStarter.join(Launcher.java:524)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:814)
	at hudson.model.Build$BuildExecution.build(Build.java:199)
	at hudson.model.Build$BuildExecution.doRun(Build.java:164)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:522)
	at hudson.model.Run.execute(Run.java:1896)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:44)
	at hudson.model.ResourceController.execute(ResourceController.java:101)
	at hudson.model.Executor.run(Executor.java:442)
Caused by: java.io.IOException: Pipe closed after 0 cycles
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:126)
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:105)
	at hudson.remoting.FlightRecorderInputStream.read(FlightRecorderInputStream.java:94)
	at hudson.remoting.ChunkedInputStream.readHeader(ChunkedInputStream.java:75)
	at hudson.remoting.ChunkedInputStream.readUntilBreak(ChunkedInputStream.java:105)
	at hudson.remoting.ChunkedCommandTransport.readBlock(ChunkedCommandTransport.java:39)
	at hudson.remoting.AbstractSynchronousByteArrayCommandTransport.read(AbstractSynchronousByteArrayCommandTransport.java:34)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:61)
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-8 is offline; cannot locate jdk_1.8_latest

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1328

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1328/display/redirect>

Changes:


------------------------------------------
[...truncated 563.29 KB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224082040",
            "environmentId": "HGADdaWIpYbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-083219",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-083219"
      }
    ]
  },
  "name": "go-testxlang_partition-272",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/24 09:17:13 Submitted job: 2023-02-24_01_17_12-9358009805508804140
2023/02/24 09:17:13 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-24_01_17_12-9358009805508804140?project=apache-beam-testing
2023/02/24 09:17:13 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-24_01_17_12-9358009805508804140
2023/02/24 09:17:13 Job state: JOB_STATE_PENDING ...
2023/02/24 09:17:43 Job still running ...
2023/02/24 09:18:13 Job still running ...
2023/02/24 09:18:43 Job still running ...
2023/02/24 09:19:13 Job still running ...
2023/02/24 09:19:43 Job still running ...
2023/02/24 09:20:13 Job still running ...
2023/02/24 09:20:43 Job still running ...
2023/02/24 09:21:13 Job still running ...
2023/02/24 09:21:43 Job still running ...
2023/02/24 09:22:13 Job still running ...
2023/02/24 09:22:43 Job still running ...
2023/02/24 09:23:14 Job still running ...
2023/02/24 09:23:44 Job still running ...
2023/02/24 09:24:14 Job still running ...
2023/02/24 09:24:44 Job still running ...
2023/02/24 09:25:14 Job still running ...
2023/02/24 09:25:44 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-24_01_17_12-9358009805508804140 failed
--- FAIL: TestXLang_Partition (549.69s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3202.743s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677227575473108618
--- FAIL: TestBigQueryIO_BasicWriteRead (5.00s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37857 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oIOPfdlbbk" is_bounded:BOUNDED windowing_strategy_id:"w0@oIOPfdlbbk"}} windowing_strategies:{key:"w0@oIOPfdlbbk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oIOPfdlbbk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oIOPfdlbbk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oIOPfdlbbk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677227575473108618\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oIOPfdlbbk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37857 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@oIOPfdlbbk" is_bounded:BOUNDED windowing_strategy_id:"w0@oIOPfdlbbk"}} windowing_strategies:{key:"w0@oIOPfdlbbk" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@oIOPfdlbbk" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@oIOPfdlbbk" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@oIOPfdlbbk" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677227575473108618\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"oIOPfdlbbk"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6b620, 0xc0000b0440})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b620, 0xc0000b0440})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6620?, 0xc0000ba050?}, {0x1136fa9, 0x39}, {0xc0005b20c0?, 0xa9bd60?, 0x1?}, {0xc0003f4f00, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a65c0?, 0xc0000ba050?}, {0xc00010e900, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0xe782a0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f4f00, 0xf}, {0xc00010e900, 0x52}, {0xeb9540, 0xc000130418})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004949c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004949c0, 0x1168fa0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.034s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5b73875ea5c31a10a8802ca30acd174eca7a33a5ef4cd16bfd4367a664fe1a44
  Associated tags:
 - 20230224-083219
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-083219
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-083219].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5b73875ea5c31a10a8802ca30acd174eca7a33a5ef4cd16bfd4367a664fe1a44].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a112653eb8c5eee18b0c70cadae9a77d69f462995601d9bd34f9f950721bfbd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a112653eb8c5eee18b0c70cadae9a77d69f462995601d9bd34f9f950721bfbd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a112653eb8c5eee18b0c70cadae9a77d69f462995601d9bd34f9f950721bfbd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4a112653eb8c5eee18b0c70cadae9a77d69f462995601d9bd34f9f950721bfbd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224082040]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:19672e5774ca77a097bf46006f89015242ce046b386bdc9ddb1f07eeee81de6c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224082040] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:19672e5774ca77a097bf46006f89015242ce046b386bdc9ddb1f07eeee81de6c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:19672e5774ca77a097bf46006f89015242ce046b386bdc9ddb1f07eeee81de6c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:19672e5774ca77a097bf46006f89015242ce046b386bdc9ddb1f07eeee81de6c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 59s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1327

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1327/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
2023/02/24 03:29:27 Job still running ...
2023/02/24 03:29:57 Job still running ...
2023/02/24 03:30:27 Job still running ...
2023/02/24 03:30:57 Job still running ...
2023/02/24 03:31:27 Job still running ...
2023/02/24 03:31:57 Job still running ...
2023/02/24 03:32:27 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-23_19_16_25-8650146483828999430 failed
--- FAIL: TestXLang_Partition (1002.17s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3631.749s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677205949284665183
--- FAIL: TestBigQueryIO_BasicWriteRead (5.09s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44111 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mjDSLnZIRM" is_bounded:BOUNDED windowing_strategy_id:"w0@mjDSLnZIRM"}} windowing_strategies:{key:"w0@mjDSLnZIRM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mjDSLnZIRM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mjDSLnZIRM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mjDSLnZIRM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677205949284665183\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mjDSLnZIRM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44111 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@mjDSLnZIRM" is_bounded:BOUNDED windowing_strategy_id:"w0@mjDSLnZIRM"}} windowing_strategies:{key:"w0@mjDSLnZIRM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@mjDSLnZIRM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@mjDSLnZIRM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@mjDSLnZIRM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677205949284665183\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"mjDSLnZIRM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:3064)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2121)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 42 [running]:
testing.tRunner.func1.2({0xf6b620, 0xc0003b3ec0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b620, 0xc0003b3ec0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e1720?, 0xc000129680?}, {0x1136fa9, 0x39}, {0xc0001d20c0?, 0xa9bd60?, 0x1?}, {0xc00046adc0, 0xf}, 0xc0000cfd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e16c0?, 0xc000129680?}, {0xc000182900, 0x52}, {0x1?}, {0xc0000cfea8, 0x2, 0x7f6880419a10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00046adc0, 0xf}, {0xc000182900, 0x52}, {0xeb9540, 0xc00065e150})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103a00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103a00, 0x1168fa0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.124s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-023154
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-023154
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:915b9921e6aa0fb84ab0a6295eb3f96d79c88345ca01abc2b378e51d276a8967
Deleted: sha256:fb86e05cedf64fe16d706f91a8c3b3df24d82036f3b3230db340ed20c7b1992a
Deleted: sha256:34122efdaabfe597875e56d66d4cef366d0ed958b83c975d550daeb9f90fae35
Deleted: sha256:e786cd4aac7a5026ce61b94b501f1021f3549b6e896a5f3c76db16636bf011ff
Deleted: sha256:90169f66264523572de443a54b5c6b7f8b08bae23a19657122c871decd64ebae
Deleted: sha256:81965b97c7d76857b3d96ba93b288febee03a13e993d96e4c16ad0a8604af5e6
Deleted: sha256:58dc2416ffec1d0fa0a8b745229584b2fefab2054a1cde338ffa23f66421ae6c
Deleted: sha256:120c45b39b3c11486c68c70045471881d693577d93d48efe09fbf2f5f7e08d3c
Deleted: sha256:1d8edfa88962baa1d5d556afcba222740aad60073d3bb847dc2c67e9bc247eab
Deleted: sha256:f85f3e75764e68c9420966ae80f7fbb1d00f47440e56b98cf9cc282b071d74b7
Deleted: sha256:94533700ca17a8024ef4bc89e219f33309f4777aba4704c0605d677a5b63be52
Deleted: sha256:45e3bcc2745d6cd95984d4638af68db36a7535d861abe248b26f4af012f66c19
Deleted: sha256:c468c8e14c545a934c058fe01a391606623d9f786620f8e7685c689298d9e53c
Deleted: sha256:b04c5cd3a81102586ab3cee7a0fba359bbebdfaf31b0ab81d0b63f9060e0e5ef
Deleted: sha256:d8f1f2fe8ca252e099d910ab86085b8b7cbafd27b5839d3168814b443bf4ed47
Deleted: sha256:e48fae15335e16ba4a572b81d04bd0f43dcd2b1c0fac911aedeb6a6d6100130f
Deleted: sha256:06ffe1aa8c553faf97377223fedf8308c4716c94185e014dc43d732571c376b2
Deleted: sha256:c52055b4e6750d99b27e669ef8ee063a1c220775051f5dce0a8b191ff3cd09c5
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-023154
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:915b9921e6aa0fb84ab0a6295eb3f96d79c88345ca01abc2b378e51d276a8967
  Associated tags:
 - 20230224-023154
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-023154
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230224-023154].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:915b9921e6aa0fb84ab0a6295eb3f96d79c88345ca01abc2b378e51d276a8967].
$ rm -rf /tmp/tmp.tegTAlO8Tp
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224022027
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224022027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230224022027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f3ceccdb29334e8162eddb80786f179d3323ceaa0145cc35ad7c5f7b22c115a2].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224022027
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1
Deleted: sha256:d876ded836d4c2029d7ad26c27529e7219f6098555dab02dd7c817a0ec76998b
Deleted: sha256:2b54aeb75d633960883b0232193c00340814a881ee2a9019229cb593256d7ee0
Deleted: sha256:af2c8c6d912f99cbc8996f14bb299b70f991a132c43963dcf91d7b170b9db897
Deleted: sha256:c500cf3ef247deeadd380fe3378cb4b7970eb9d4c33abb4cd19290a69516304b
Deleted: sha256:427c0e00ea9114f8cd90866097a2aff8fc4a42cf2b220cedc30e98eabd2b0f0e
Deleted: sha256:81ef5d69a98e07279dad729c6cbc8c9aae1829660ae736a7c7b51ffb70e4b24a
Deleted: sha256:6a7aedca01d9d6eda45dc18e2bc1f82b07d1f4b358e7591d9e73415f0323bdc6
Deleted: sha256:1d031e6fce8d6789a3cbe9d138d70f356d9264ac8d377790bd3e07125d37c6ef
Deleted: sha256:b3c2276484efd68757d7a669e737f3c59382d71daf349dd2506b9931d0efe68a
Deleted: sha256:30c6419017e79fac85ee0b30f43be75d351f6c079c393fd7f0495206d2558f7f
Deleted: sha256:6f4c61d8425e89ad90af58e7186a737e6fae390cdf7b941f4212e1cfb90c19c9
Deleted: sha256:7601643c5954da3bb59745fe3e82a5db4563c09318a5658709c6bbf8b058af1f
Deleted: sha256:ca536088040cfb95aff4efed73a66a179ecf881abf7a8d6621eae3c4b1b3fb46
Deleted: sha256:8a322eeef2e16f62e49ffdca59b00fb8f04667f68c45445aef2f26a8fec1fa3a
Deleted: sha256:5e0de96bb66c25e6dc8eb25252b6b8f4ccac93263dc72b8702e24d8bd12dacac
Deleted: sha256:0a04268218fb97cc5fe7cf0613cf395dc5dff25c7a473f4490ec6c4c1d35267f
Deleted: sha256:66507d772f8fb7f7148fb4e851b8ea86365e95cba1aeeb97ebbe3ec609452a5e
Deleted: sha256:de4ea3a3b78b962b0d69e3e04d537125add299f5d7fd3de3bafc7a02fee31031
Deleted: sha256:c707dab4adc34a044802bad8c4acb143151e384400d42c1808354f92571792ba
Deleted: sha256:a19aff3487f01d6059277f24d9e17866215b7489ad37031941cfb2249c7883cb
Deleted: sha256:7a2bc5f48f04e1156bde578c7556d94507661069b85c374404258bce6a8b8c5c
Deleted: sha256:98bf32fe06805170a6458d530dd22262b124e983e962d3ee4da49353a21f36f5
Deleted: sha256:2962de91b977be36e8bbd85cccdb6ad789c0992343b456ffe5f4098cfe535752
Deleted: sha256:1fcb672a36779de26dba3c16b09af4ae3d69f4f37b604ed0c864cf922bbb9181
Deleted: sha256:510b2908cf6f5a1fa25ced0978c09e2b283a00007f02937a9e71dd22423713fe
Deleted: sha256:c2c221e6c44bcde86544a47e82af1fc6a70f4dec1e07ecb6178a31362d22c8cf
Deleted: sha256:349b460523bea375d809250d248e3d598bbc414c21344c7f2316acbda6fd8fdb
Deleted: sha256:ad21829bb74bdba7d87e9910d9564fbacdee7a7b9bf01d176f7d45aa861ab16c
Deleted: sha256:612b5b005d37438419287f15c8c1ce5acd6ba3a31ceb00224e163dfa1ad03b18
Deleted: sha256:4793e847748d3a895f567555c7716e3ff0fd25417dfb8da1affc1d70e3482e79
Deleted: sha256:2d4521fe44a24acfd655ff48601fbc457b67b082186d1464bd0d3ac83795b0e0
Deleted: sha256:33f5d0b7bfdaf8aec49c2a4779294fb6116a3e15ff56adb6baa087e25755b9c7
Deleted: sha256:fc09ccfa41cf326e30fa3ea080ea003482aca311592adcd2df2a03505ed67178
Deleted: sha256:840db5818700af0ce8529ea9d34e531c155bfbb27b4ccaefd7b49058a6e382ab
Deleted: sha256:2339e049781406783c4c6424541102209b9cfd6b627d14b8a5176942165fb452
Deleted: sha256:c659ecaed37bafc6a2a3ed85fe003ab03fa314b91efd2292a6d587be9987178a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224022027]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230224022027] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:00f4768ff77ee8fc0808b368739ccd74d044a0c9cb75a93e5096490f890492b1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3035195.
Stopping expansion service pid: 3035196.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 12m 56s
232 actionable tasks: 174 executed, 47 from cache, 11 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1326

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1326/display/redirect?page=changes>

Changes:

[noreply] Fix go postcommit naming (#25613)


------------------------------------------
[...truncated 1.01 MB...]
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223202032",
            "environmentId": "PitcqZyLELbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152"
      }
    ]
  },
  "name": "go-testxlang_partition-890",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/23 21:17:01 Submitted job: 2023-02-23_13_17_00-599634461359292007
2023/02/23 21:17:01 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-23_13_17_00-599634461359292007?project=apache-beam-testing
2023/02/23 21:17:01 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-23_13_17_00-599634461359292007
2023/02/23 21:17:01 Job state: JOB_STATE_PENDING ...
2023/02/23 21:17:31 Job still running ...
2023/02/23 21:18:01 Job still running ...
2023/02/23 21:18:31 Job still running ...
2023/02/23 21:19:01 Job still running ...
2023/02/23 21:19:31 Job still running ...
2023/02/23 21:20:01 Job still running ...
2023/02/23 21:20:31 Job still running ...
2023/02/23 21:21:01 Job still running ...
2023/02/23 21:21:31 Job still running ...
2023/02/23 21:22:01 Job still running ...
2023/02/23 21:22:31 Job still running ...
2023/02/23 21:23:01 Job still running ...
2023/02/23 21:23:31 Job still running ...
2023/02/23 21:24:01 Job still running ...
2023/02/23 21:24:32 Job still running ...
2023/02/23 21:25:02 Job still running ...
2023/02/23 21:25:32 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-23_13_17_00-599634461359292007 failed
--- FAIL: TestXLang_Partition (553.91s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3212.301s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677184357165212494
--- FAIL: TestBigQueryIO_BasicWriteRead (18.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36801 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@eUNWywhoFn" is_bounded:BOUNDED windowing_strategy_id:"w0@eUNWywhoFn"}} windowing_strategies:{key:"w0@eUNWywhoFn" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@eUNWywhoFn" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@eUNWywhoFn" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@eUNWywhoFn" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677184357165212494\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"eUNWywhoFn"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:36801: connect: connection refused" [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36801 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@eUNWywhoFn" is_bounded:BOUNDED windowing_strategy_id:"w0@eUNWywhoFn"}} windowing_strategies:{key:"w0@eUNWywhoFn" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@eUNWywhoFn" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@eUNWywhoFn" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@eUNWywhoFn" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677184357165212494\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"eUNWywhoFn"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:36801: connect: connection refused"

goroutine 19 [running]:
testing.tRunner.func1.2({0xf6b620, 0xc000690940})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b620, 0xc000690940})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005090c0?, 0xc0005196d0?}, {0x1136fa9, 0x39}, {0xc0000f00c0?, 0xa9bd60?, 0x1?}, {0xc00048ecc0, 0xf}, 0xc0005e5d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000509060?, 0xc0005196d0?}, {0xc0005a63c0, 0x52}, {0x1?}, {0xc0005e5ea8, 0x2, 0x7f31f24a3fb0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ecc0, 0xf}, {0xc0005a63c0, 0x52}, {0xeb9540, 0xc00048ffd0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x1168fa0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	21.488s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.041s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5dd8b01c1cfca6cb57b69fd2443ac83e0543d8857f55da3f88e5ed6a4334dde0
Deleted: sha256:a7ed6f015132c681ac02ffd7f53e640f2836fd6e9bb385267f8ac85f8f0645c1
Deleted: sha256:2fc40b66289ee8d8947b3183cf64178683ce1ae25d74e2b55faf0963894467a0
Deleted: sha256:3f97fc201017d73f0a5660d2da28f2190a8ca3f6343aadad228a3e923a9b709b
Deleted: sha256:ab3d042ce459689a9ef179e0410f09b3497db39ba087aeafa168cf8b4457338a
Deleted: sha256:108313d50a2d897b0d9c410bd7bc750501ba033ce95579be60a6a9eb7770611a
Deleted: sha256:57d45faf67dbed46ae91506024888e716ad7d16cb6a6d61ae7f67fbad45cb4ea
Deleted: sha256:01199e7d021f25b043d67ca0a5fa830341fe3ac63a46b5a31cf3455825f1f9f8
Deleted: sha256:e4a698edf716d5d21e846333572df0d2cd4f260928e5d4bad5ee3a439a5fb08d
Deleted: sha256:199436d9da028cd6e9ae4dd3ae95e70bdbfcec22ab50a578543416ee3bf13117
Deleted: sha256:354132df1729b9bd24a50e1d380a92316a19f18dfa221ddd26aa26d532be89fa
Deleted: sha256:d47dbab9d8ab79efa0e194719c04ae65028a3abfdcd1b145d2ee2ed08e0eb449
Deleted: sha256:136814c01344f95b36e06ce4ba344fcc78a977b84938367430bca0c7d0b9823b
Deleted: sha256:85e8d9677845248b3981ffd18db4bc7405e9eb412552d055bc32a40639fcbc41
Deleted: sha256:1b356712f6d99362271e9d1683f93a80edb002862f544136cfc8b0620d5a3233
Deleted: sha256:def5bbd2e834f53c382501d2d8a82d09f6e036f107e486ca4001d5441c1addb5
Deleted: sha256:c1eacfaef8a00cc49b0255f3cd5b21d462ee4003f436e8ad32e2be6137419191
Deleted: sha256:b00f04b850cae169b22072cabf12020536f985eea8b5007acecf4f280efe466f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5dd8b01c1cfca6cb57b69fd2443ac83e0543d8857f55da3f88e5ed6a4334dde0
  Associated tags:
 - 20230223-203152
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-203152].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5dd8b01c1cfca6cb57b69fd2443ac83e0543d8857f55da3f88e5ed6a4334dde0].
$ rm -rf /tmp/tmp.sXsfGdRS5X
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223202032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fb8b722c20a54c02aae96c82a43022ad06d0dc7b129448efea679ae5d23aef0a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223202032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223202032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223202032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b360144d8b1dce41e052c7808418aad9f51d5015f9bccd362e2542f2523f342c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2486068.
Stopping expansion service pid: 2486069.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 56s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1325

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1325/display/redirect>

Changes:


------------------------------------------
[...truncated 595.01 KB...]
execnet==1.9.0
fastavro==1.7.1
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.78.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.5.0
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.1
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.1
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.2
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.68.1
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.2
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.6
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0.1
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.6.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.4.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.4
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.5.1
Werkzeug==2.2.3
wheel==0.38.4
wrapt==1.14.1
zipp==3.13.0
zstandard==0.19.0
Removing intermediate container e565f50762f0
 ---> d95852191c59
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> c09f0bfe8d56
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> a76c4e6719b0
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> e0638ca05c57
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 3bee0ad2c787
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 6629fedff105
Removing intermediate container 6629fedff105
 ---> 98dba2fa87a3
Step 22/32 : FROM beam as third_party_licenses
 ---> 98dba2fa87a3
Step 23/32 : ARG pull_licenses
 ---> Running in 45b4d04e813d
Removing intermediate container 45b4d04e813d
 ---> 25a6b806acfd
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 432d454f3fe9
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 9b7cce263e2e
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in ff9dac0a1873
Removing intermediate container ff9dac0a1873
 ---> a7eec8e952c4
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 546342cff3f5
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 1ab9dfaabd59
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=21f3359e84dd67a4e47b44e863442a320b43e152d8eb1504460044c9156f5bfc
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 1ab9dfaabd59
 ---> c54b2db09630
Step 29/32 : FROM beam
 ---> 98dba2fa87a3
Step 30/32 : ARG pull_licenses
 ---> Running in e456884037a7
Removing intermediate container e456884037a7
 ---> 643e3ff04378
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 2b458bcec9bf
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in d115c8fe20f0
Removing intermediate container d115c8fe20f0
 ---> 12ca37f0c280
Successfully built 12ca37f0c280
Successfully tagged apache/beam_python3.8_sdk:2.47.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


> Task :runners:google-cloud-dataflow-java:setupXVR
> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerSetup

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava
go1.19.6: already downloaded in /home/jenkins/sdk/go1.19.6
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.3
go1.19.3: already downloaded in /home/jenkins/sdk/go1.19.3
/home/jenkins/go/bin/go1.19.3 test -v ./test/integration/xlang ./test/integration/io/xlang/... -p 3 -timeout 3h --runner=dataflow --project=apache-beam-testing --region=us-central1 --environment_type=DOCKER --environment_config=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-143340 --staging_location=gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26173 --temp_location=gs://temp-storage-for-end-to-end-tests/temp-validatesrunner-test/test26173 --endpoint= --sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223142041 --kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.47.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.47.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.47.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:36067
FATAL: command execution failed
java.io.IOException: Backing channel 'apache-beam-jenkins-12' is disconnected.
	at hudson.remoting.RemoteInvocationHandler.channelOrFail(RemoteInvocationHandler.java:215)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:285)
	at com.sun.proxy.$Proxy142.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1215)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1207)
	at hudson.Launcher$ProcStarter.join(Launcher.java:524)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:814)
	at hudson.model.Build$BuildExecution.build(Build.java:199)
	at hudson.model.Build$BuildExecution.doRun(Build.java:164)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:522)
	at hudson.model.Run.execute(Run.java:1896)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:44)
	at hudson.model.ResourceController.execute(ResourceController.java:101)
	at hudson.model.Executor.run(Executor.java:442)
Caused by: java.io.IOException: Pipe closed after 0 cycles
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:126)
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:105)
	at hudson.remoting.FlightRecorderInputStream.read(FlightRecorderInputStream.java:94)
	at hudson.remoting.ChunkedInputStream.readHeader(ChunkedInputStream.java:75)
	at hudson.remoting.ChunkedInputStream.readUntilBreak(ChunkedInputStream.java:105)
	at hudson.remoting.ChunkedCommandTransport.readBlock(ChunkedCommandTransport.java:39)
	at hudson.remoting.AbstractSynchronousByteArrayCommandTransport.read(AbstractSynchronousByteArrayCommandTransport.java:34)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:61)
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-12 is offline; cannot locate jdk_1.8_latest

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1324

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1324/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223082032",
            "environmentId": "pTRZzvLXhabeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139"
      }
    ]
  },
  "name": "go-testxlang_partition-471",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/23 09:17:16 Submitted job: 2023-02-23_01_17_15-6673196444255166401
2023/02/23 09:17:16 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-23_01_17_15-6673196444255166401?project=apache-beam-testing
2023/02/23 09:17:16 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-23_01_17_15-6673196444255166401
2023/02/23 09:17:16 Job state: JOB_STATE_PENDING ...
2023/02/23 09:17:46 Job still running ...
2023/02/23 09:18:16 Job still running ...
2023/02/23 09:18:46 Job still running ...
2023/02/23 09:19:16 Job still running ...
2023/02/23 09:19:46 Job still running ...
2023/02/23 09:20:16 Job still running ...
2023/02/23 09:20:46 Job still running ...
2023/02/23 09:21:16 Job still running ...
2023/02/23 09:21:46 Job still running ...
2023/02/23 09:22:16 Job still running ...
2023/02/23 09:22:46 Job still running ...
2023/02/23 09:23:16 Job still running ...
2023/02/23 09:23:46 Job still running ...
2023/02/23 09:24:16 Job still running ...
2023/02/23 09:24:46 Job still running ...
2023/02/23 09:25:17 Job still running ...
2023/02/23 09:25:47 Job still running ...
2023/02/23 09:26:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-23_01_17_15-6673196444255166401 failed
--- FAIL: TestXLang_Partition (579.58s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3275.347s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677141135161689535
--- FAIL: TestBigQueryIO_BasicWriteRead (17.78s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41803 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RMlkiOAzOq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RMlkiOAzOq"}}  windowing_strategies:{key:"w0@RMlkiOAzOq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RMlkiOAzOq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RMlkiOAzOq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RMlkiOAzOq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677141135161689535\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RMlkiOAzOq"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:41803: connect: connection refused" [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41803 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RMlkiOAzOq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RMlkiOAzOq"}}  windowing_strategies:{key:"w0@RMlkiOAzOq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RMlkiOAzOq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RMlkiOAzOq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RMlkiOAzOq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677141135161689535\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RMlkiOAzOq"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:41803: connect: connection refused"

goroutine 50 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00048af00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00048af00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000488b40?, 0xc0005ab7c0?}, {0x1136f49, 0x39}, {0xc00014e0c0?, 0xa9be80?, 0x1?}, {0xc0005ace30, 0xf}, 0xc000175d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488ae0?, 0xc0005ab7c0?}, {0xc0005cc360, 0x52}, {0x1?}, {0xc000175ea8, 0x2, 0x7fb8eda7a448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005ace30, 0xf}, {0xc0005cc360, 0x52}, {0xeb9520, 0xc0000424b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00049b1e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00049b1e0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	20.818s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19250a4e6d0824df1ff182f0ab395cd9dd753f262e5e014c62e8b0b5e4fa3d4c
Deleted: sha256:16735af233638c11bca8a9887d971119bc4a0a23c6ddfaa1d1514aed8b337b9e
Deleted: sha256:99436ed83014d7295cc5f4f487e71d39a671cea225636e0d614bb5a54060ca94
Deleted: sha256:dc1add5be27781327d6c8f627dd83135d5f9875825aa1236f4cd96d66f6b8fb9
Deleted: sha256:9fa693f23950d953f61c8075dd78a56c17e353b16a8a86637d0e1adfeadd96a4
Deleted: sha256:749cf1bdacc4620e89833bda7e25be44f1d52a64bcf1be5df5add55042e56ffc
Deleted: sha256:2fe4c9edc002a46af0a6c7e1dd057cc872f4c8dd57beabce675ce36dcf5aa0d8
Deleted: sha256:1bdb64203dcede7f25ae26d288ad9b2c9d27964cee04e094e4a967c09767a878
Deleted: sha256:be9a039fde749ed3ac513e4aa4a9621ad001c35846040383aca87dae71f756ac
Deleted: sha256:793bff041204cbef1c79fac3a66e702dbbfcef24001656fb3629194bf0d2e3c2
Deleted: sha256:8a6db5c8edc0dfeb8978f57cba05e3d6882556d829b2e71c8daf88d54856ba9a
Deleted: sha256:789364cc208546a2366516d50650734e1f5a46b2369a69a60877096858a4de89
Deleted: sha256:21d17b2eea15ecca4b9f35f5571371b119b5d29a393c5a51cfbc3955d2c2b947
Deleted: sha256:a00db3c8d0f8686bd24c23d0db328be7cf8760d8b725f78da34d89ef1371ec69
Deleted: sha256:c837d8d224b4a40aac55d89fb2f116f6d8fdd285c32ed331f8014bf184529eff
Deleted: sha256:15b9ab7e9e45199b95730b27d67fce2691441e10e5331ddfc2e69c96d60b759c
Deleted: sha256:dd8a5233b59b375850cd2f8f48b06ed4547808f7730b26fe676d85403058da46
Deleted: sha256:6965b1e9e1298017992fd05362a4a8a95848233952b546996eb53f2c714d516b
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19250a4e6d0824df1ff182f0ab395cd9dd753f262e5e014c62e8b0b5e4fa3d4c
  Associated tags:
 - 20230223-083139
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-083139].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19250a4e6d0824df1ff182f0ab395cd9dd753f262e5e014c62e8b0b5e4fa3d4c].
$ rm -rf /tmp/tmp.rP8CEwL3FM
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223082032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223082032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223082032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e7525d8df65d17e48a438264bc98bf2c214ec74cc5f7b4ad96fa095d49309407].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223082032
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223082032]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223082032] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7f2c87d4b734b008bf2312b73a281fbc456bb5c9f356039a789537ee7c7fc887].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1547662.
Stopping expansion service pid: 1547663.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 44s
232 actionable tasks: 152 executed, 68 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/73gyzzrv6w5ny

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1323

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1323/display/redirect>

Changes:


------------------------------------------
[...truncated 595.53 KB...]
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223022238",
            "environmentId": "URvSSEhSgcbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.47.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550"
      }
    ]
  },
  "name": "go-testxlang_partition-459",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/23 03:21:20 Submitted job: 2023-02-22_19_21_20-11072412244207831441
2023/02/23 03:21:20 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-22_19_21_20-11072412244207831441?project=apache-beam-testing
2023/02/23 03:21:20 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-22_19_21_20-11072412244207831441
2023/02/23 03:21:20 Job state: JOB_STATE_PENDING ...
2023/02/23 03:21:50 Job still running ...
2023/02/23 03:22:20 Job still running ...
2023/02/23 03:22:50 Job still running ...
2023/02/23 03:23:20 Job still running ...
2023/02/23 03:23:50 Job still running ...
2023/02/23 03:24:20 Job still running ...
2023/02/23 03:24:50 Job still running ...
2023/02/23 03:25:21 Job still running ...
2023/02/23 03:25:51 Job still running ...
2023/02/23 03:26:21 Job still running ...
2023/02/23 03:26:51 Job still running ...
2023/02/23 03:27:21 Job still running ...
2023/02/23 03:27:51 Job still running ...
2023/02/23 03:28:21 Job still running ...
2023/02/23 03:28:51 Job still running ...
2023/02/23 03:29:21 Job still running ...
2023/02/23 03:29:51 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-22_19_21_20-11072412244207831441 failed
--- FAIL: TestXLang_Partition (549.80s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3189.240s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677119852644154861
--- FAIL: TestBigQueryIO_BasicWriteRead (20.02s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37085 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dlHSUKuOxL"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dlHSUKuOxL"}}  windowing_strategies:{key:"w0@dlHSUKuOxL"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dlHSUKuOxL"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dlHSUKuOxL"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dlHSUKuOxL"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677119852644154861\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dlHSUKuOxL"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:37085: connect: connection refused" [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37085 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dlHSUKuOxL"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dlHSUKuOxL"}}  windowing_strategies:{key:"w0@dlHSUKuOxL"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dlHSUKuOxL"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dlHSUKuOxL"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dlHSUKuOxL"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677119852644154861\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dlHSUKuOxL"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:37085: connect: connection refused"

goroutine 30 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0000cc040})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0000cc040})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a71c0?, 0xc0001b1a90?}, {0x1136f49, 0x39}, {0xc0001d20c0?, 0xa9be80?, 0x1?}, {0xc000042db0, 0xf}, 0xc0005e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7160?, 0xc0001b1a90?}, {0xc000180900, 0x52}, {0x1?}, {0xc0005e9ea8, 0x2, 0x7f6770606c20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042db0, 0xf}, {0xc000180900, 0x52}, {0xeb9520, 0xc0001a8380})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ccea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ccea0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	23.066s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.161s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.113s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.141s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca81c4d1ed9563b880876313c4076cf74a4df554400c7b3d8a41a59c2a046e0c
Deleted: sha256:d82bd8abdc9cb594af5e9d3d596efbd654380561e8ff1c647ccbefc690f43bc9
Deleted: sha256:6f9c878d4a225b47cd883151ca498de5a932f8a3a6edf886671fcfc06fe7015c
Deleted: sha256:2c76b283a6ea89abc39b6ae747ceafee5b36ae8dabc2147e624ca976550bab9d
Deleted: sha256:cc7a754863df31b8e3d18444245afdaa41a7982e57470e6c961a903013e0fdc5
Deleted: sha256:713681bc5426530c5d8ea546f8fc68bf0f6dec7c0950280b9cc6d37c1357100d
Deleted: sha256:69ee765f14dbfb0b85dc098a1a7f3ffd5a9b79ad020be3ae510d9fd1710c80c3
Deleted: sha256:c454582ef6b6c3684bd07fbb6c8a0e810365b7782662c6facb9f1c5732a0f5fe
Deleted: sha256:de07af1c4b0fa69049f1c7854d062c5a432a12c7fc7edcf8c8f1ac0084b629cc
Deleted: sha256:9d2592eb04eed62c7c9ed1460d642c6cef08cb0bbeb108a7cec8e4e04eb4c8a3
Deleted: sha256:9def0fffe8ac2ada02b1d280f9554317a510c7746c77c4260e64c862067934d2
Deleted: sha256:d099830e370c2a2117a70dcfcfc7658a2461c009f7475fab6d74ddb41bb29cbe
Deleted: sha256:cef1593c72f5c4145e77e82db82f1417f31cbd8029969541763ffb5fa87c0e00
Deleted: sha256:3c09771f369249ffda608813a70ad0488b234dbb4d160774325278815fad2650
Deleted: sha256:1c17cf2a25c6af0f3070ad1849f7d8286e40717307f0316163c32d3458b0d9db
Deleted: sha256:a7d46ed737d81177e1073db927f57417a744a8880711fbe332b36eec19197f24
Deleted: sha256:cb099f651b7591cb3fa3bb0dc5f8e1d07196939c61cfdf2800a191991c01f1d6
Deleted: sha256:3f4fd3ca15c3444504105c37f11e61c07cf96a392ddee6fddc54a180b3a0776d
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca81c4d1ed9563b880876313c4076cf74a4df554400c7b3d8a41a59c2a046e0c
  Associated tags:
 - 20230223-023550
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230223-023550].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ca81c4d1ed9563b880876313c4076cf74a4df554400c7b3d8a41a59c2a046e0c].
$ rm -rf /tmp/tmp.SuoRvOYpf5
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223022238
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223022238]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230223022238] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9868cfa2e3715cae5f05648225a5c45e5a56f321f646b94fb9ffedbdb924489].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223022238
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223022238]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230223022238] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:1ccf6582e602def602db4e019e73459c12f434ae9957008ffd4065ec4a4acc49].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1275510.
Stopping expansion service pid: 1275511.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 10s
232 actionable tasks: 170 executed, 50 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1322

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1322/display/redirect?page=changes>

Changes:

[noreply] Bump github.com/testcontainers/testcontainers-go in /sdks (#25517)

[noreply] [Avro] Use "extensions/avro" instead of avro from"core" in Java SDK

[Alexey Romanenko] Deprecate Avro API classes in "sdks/java/core"

[noreply] PCollection data sampling for Java SDK harness #25064 (#25354)

[noreply] Add partitioned reads to JDBC SchemaIO (#25577)

[noreply] Bump github.com/aws/aws-sdk-go from 1.33.0 to 1.34.0 in /sdks (#25469)

[noreply] ML model evaluation website page (#25589)

[noreply] Add Data Sampling capability URN to Java SDK (#25593)

[noreply] Add anchor link for the logo wall (#25594)

[noreply] Read API Source v2 (#25392)

[Danny McCormick] Moving to 2.47.0-SNAPSHOT on master branch.


------------------------------------------
[...truncated 1.03 MB...]
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.47.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1",
              "beam:protocol:data_sampling:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222202247",
            "environmentId": "RGTOlXEumnbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517"
      }
    ]
  },
  "name": "go-testxlang_partition-213",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/22 21:31:03 Submitted job: 2023-02-22_13_31_02-14786719686752573990
2023/02/22 21:31:03 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-22_13_31_02-14786719686752573990?project=apache-beam-testing
2023/02/22 21:31:03 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-22_13_31_02-14786719686752573990
2023/02/22 21:31:03 Job state: JOB_STATE_PENDING ...
2023/02/22 21:31:33 Job still running ...
2023/02/22 21:32:03 Job still running ...
2023/02/22 21:32:33 Job still running ...
2023/02/22 21:33:03 Job still running ...
2023/02/22 21:33:33 Job still running ...
2023/02/22 21:34:03 Job still running ...
2023/02/22 21:34:33 Job still running ...
2023/02/22 21:35:03 Job still running ...
2023/02/22 21:35:33 Job still running ...
2023/02/22 21:36:03 Job still running ...
2023/02/22 21:36:33 Job still running ...
2023/02/22 21:37:03 Job still running ...
2023/02/22 21:37:33 Job still running ...
2023/02/22 21:38:03 Job still running ...
2023/02/22 21:38:33 Job still running ...
2023/02/22 21:39:04 Job still running ...
2023/02/22 21:39:34 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-22_13_31_02-14786719686752573990 failed
--- FAIL: TestXLang_Partition (554.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3211.897s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677098799043352037
--- FAIL: TestBigQueryIO_BasicWriteRead (19.01s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35777 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RKhTLUWZsq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RKhTLUWZsq"}}  windowing_strategies:{key:"w0@RKhTLUWZsq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RKhTLUWZsq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RKhTLUWZsq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RKhTLUWZsq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677098799043352037\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RKhTLUWZsq"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:35777: connect: connection refused" [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35777 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RKhTLUWZsq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RKhTLUWZsq"}}  windowing_strategies:{key:"w0@RKhTLUWZsq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RKhTLUWZsq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RKhTLUWZsq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RKhTLUWZsq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677098799043352037\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RKhTLUWZsq"
expansion failed
	caused by:
rpc error: code = Unavailable desc = connection error: desc = "transport: Error while dialing dial tcp 127.0.0.1:35777: connect: connection refused"

goroutine 56 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00002b6c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00002b6c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480860?, 0xc0000c60f0?}, {0x1136f49, 0x39}, {0xc00015e180?, 0xa9be80?, 0x1?}, {0xc000137d20, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480800?, 0xc0000c60f0?}, {0xc00059e360, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7fdd7ab9ace0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137d20, 0xf}, {0xc00059e360, 0x52}, {0xeb9520, 0xc00049e200})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000007ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000007ba0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	22.049s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.038s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.063s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6969bbbd6eefe20c2b256383e931f4b73a5f1aeddce261b1f7ea3cdac263052f
Deleted: sha256:7cbbc1f981e89ac92fd3a5de13ebeb8016b954d233aba16f64b7ea96ec2a3d80
Deleted: sha256:a9012cc0dff1e0cbc51320d23927d3791b786dcb808f8e210a5354a66e107aad
Deleted: sha256:2a0a7ada749d54496c883ef1098a212e0fe75b115158f35128c9accedc9e2416
Deleted: sha256:62f41feafe73a29b87ef03cf983ea64471e2209cf1e981a507cafa15e2bdf575
Deleted: sha256:2625ea08552157c2dedf6460641543a30a84691aaa61405fb62956974eea585c
Deleted: sha256:8cddf2e7cc8561ce3c9519787f5463997a63e26847444d40816480b6b869952d
Deleted: sha256:89cd9c192c5f3e98ce32277081f39d8de9c84b49cacae281f3bd93a9819ec915
Deleted: sha256:57c629d232e1be915d607f5e1c8da27dd7ff8e0dfe49fd90f23359052b4f84bc
Deleted: sha256:001c721ca1aa8b72d51bed945dae5afb160c737eb483b687758c29120e9d31ff
Deleted: sha256:5fa8b87f6abc883df85a521d2a93a6d070bba24213eca6e7dbd987fbdeb37b3b
Deleted: sha256:435904b37a3ee0ec57b9914baadbe58a6aefe50b449b1302811a27a20303b8c8
Deleted: sha256:2b93ae6db69e716907b0bfd5f788e891ab9e42e52d15c056641152c87820bcde
Deleted: sha256:922bf73667492743df262096da4b19aa92b461f676ab28177e4447136ff4239f
Deleted: sha256:54a3151487c18c31610de3a5d23af4eae19db8354c7de9e08a9686fb537420ad
Deleted: sha256:9c4c45feb7dd02d5d0aaed9dc1223844a1b93913617aa4664c2f05717eb1e0ce
Deleted: sha256:ab93c71eecce08d5246ed7e93357f3a555f028a2fe879efb98e6b1d65dd107c2
Deleted: sha256:60d96a86c194266843c0efdf3553352fe53078c7d643262033bd06f5ac9f3731
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6969bbbd6eefe20c2b256383e931f4b73a5f1aeddce261b1f7ea3cdac263052f
  Associated tags:
 - 20230222-204517
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-204517].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6969bbbd6eefe20c2b256383e931f4b73a5f1aeddce261b1f7ea3cdac263052f].
$ rm -rf /tmp/tmp.wHiHkvPyKV
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222202247
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222202247]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222202247] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:752ecd744dad712171fa50aad1ff6df7b2159c9adfa1a989c19ab5f81e3d8a12].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222202247
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29
Deleted: sha256:c810e15b20e494a1aead8185cd91c1560507371a54f2a3d1f1a5e3aa3c10a7ad
Deleted: sha256:05730554e67702bfcde84aa0e67def2a2e2a92211b52198650a0251fe6955c09
Deleted: sha256:bb70ea0df47f027b46440af6d39bfe97898ded64ad819f0dfb6426b8ea75efe0
Deleted: sha256:b0a451c9b8a717485639d716d8ae1402db80258a5a3f50baae11d43929543312
Deleted: sha256:38ace2b43ea89f12d239b3e9ed615579e98d700e585bea5693036bc9b25052ba
Deleted: sha256:7cec70e262764c03427abcfaf19610263693cd33b9d0ae7842a872204ab9409a
Deleted: sha256:2d0a22c35ff408490d6192ae9a1fb02cd2db416588595ef3f6fb01249c82592c
Deleted: sha256:fb83925e218978acabb2f06db93ded371ddfef3d039264a76736bdbe43c7ceb1
Deleted: sha256:01529eda1040303927421d5bae639a8d3e142f1a7863011621f7968e366249bd
Deleted: sha256:ca90907010d46bd53dc4c186b026f4691a4767d223bb163bf625420e51230041
Deleted: sha256:d110c9a0824003521b48828e1079a198a8c30c9900666dc41770483bd6fcc879
Deleted: sha256:9d6862bf6ccf873a414a8875cddfb8ccd02331923a62021272c5cee601df5f25
Deleted: sha256:7fabd1e19a2f450a4dec7471c5feee350a4b3c0fd4f4594b5551f4fdd97070a1
Deleted: sha256:f4a62a42c4a1f70667e525640f70fd496882b0f7c2b0b3ad78eb287fca42c7d1
Deleted: sha256:049f77a5ac361e37b682a99697e2d77c6e974aa89337a75d88a10433d41d8ede
Deleted: sha256:e3b590470d701d6efc4412e931e7b150d05239b2131bb1a5ca9a94f718fce130
Deleted: sha256:f1fc2c5d2ac1eed94d7393c38cac628e824e95cf3dff57cb065d0d77c0e5d1db
Deleted: sha256:ef20c527f8ade49d41e61077d3f83fbe3d6f5667e02b4cac8823fa6df8da2f16
Deleted: sha256:9eb30ab5d673332ca6a18d65b49b323743794f8752fcbec378cd76db2129d4a0
Deleted: sha256:9efb260590fc16aad55b8ad8dc939e936e868d25043906e565a1076de0616479
Deleted: sha256:687d0ac0bc0982f8d7befc6f438e03cea8a2114f3293e62e480cd78d93ac173a
Deleted: sha256:a0436d9cf00e2ef160ada7a74cbfeb62bb452b525fd353eb81998bac29a8bbd7
Deleted: sha256:34a084ec422a10463b37ca910f2295813f7810d5bdc121eab56aef53c5a8d74b
Deleted: sha256:c0b6cec3eae2de286107e967d0596d699832d72eb7b984684082280d16b94da2
Deleted: sha256:8f358cfa86887c4d4ff599b13491a77c78b73578e5568ae704f5cb15194f7b4a
Deleted: sha256:a835a3ed96bb9562a313eba1ca75b7755d08f90119e5927e527a1da1c5202401
Deleted: sha256:7507fb81f6f62b30329716bb6a286d547ff59e195dbd46d4c468f15faa1dab1c
Deleted: sha256:7ac02a47dd2811d41d84f992390aec93cf3273dafd70d64c4f566b14ad98e606
Deleted: sha256:41ad122f5eb6b87ea73cb1ec51582c2786eea89d9d40a0f7da52b2d1df65172c
Deleted: sha256:8524126cdcae3c04e387b477725362e20f0020f25bea7ad030b9a4cc38b7ebe0
Deleted: sha256:cccabac43e8f4a72b01c0eee668fc8c0e64f16220fc1fe34d2050b50b9ee5d15
Deleted: sha256:aeb071a960b599bcfcf272978ed46325f4860ebf13783797e7902083df9db5ac
Deleted: sha256:c247b091eac89216832e0f3f887664e96ef846631fd689f78794c2a4abbbe595
Deleted: sha256:518ef7153c7cb575e9db19a7ad61a04ccad6776e2791763e6f5a483936d67cc8
Deleted: sha256:121742db7691ec5b26ae084cb559a1ec5ede3b56fcfaf63ebfd76ecb320f0897
Deleted: sha256:ec2d9b4bd15d5ce678cdced63b68c800f8630a661f7f1bf93efd674ab2a695ab
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222202247]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222202247] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5a783e10bdd524fb4563fd13f40aa2b73a898fcaeba553d1eab424c2e4079a29].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1223828.
Stopping expansion service pid: 1223829.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 17m 55s
232 actionable tasks: 215 executed, 7 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1321

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1321/display/redirect>

Changes:


------------------------------------------
[...truncated 608.95 KB...]
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
89b302ddebe4: Preparing
5456b79a3e48: Preparing
ba49748a590f: Preparing
c66e4ae7d86f: Preparing
e7b97328b6a8: Preparing
4551c4525f2b: Preparing
e47f7503b5d3: Preparing
62d2656807e7: Preparing
e98542e84725: Preparing
786f85e246fc: Preparing
a118867844a0: Preparing
1f15b778adc8: Preparing
69923d7387b2: Preparing
c1874f32062c: Preparing
4568910c2995: Preparing
26eafd96cbc2: Preparing
e98542e84725: Waiting
62d2656807e7: Waiting
e47f7503b5d3: Waiting
28a3fbb997db: Preparing
786f85e246fc: Waiting
17efc79ac0fe: Preparing
1f15b778adc8: Waiting
0b6859e9fff1: Preparing
a118867844a0: Waiting
11829b3be9c0: Preparing
69923d7387b2: Waiting
dc8e1d8b53e9: Preparing
9d49e0bc68a4: Preparing
8e396a1aad50: Preparing
28a3fbb997db: Waiting
4551c4525f2b: Waiting
c1874f32062c: Waiting
4568910c2995: Waiting
26eafd96cbc2: Waiting
17efc79ac0fe: Waiting
9d49e0bc68a4: Waiting
11829b3be9c0: Waiting
e7b97328b6a8: Pushed
ba49748a590f: Pushed
89b302ddebe4: Pushed
c66e4ae7d86f: Pushed
5456b79a3e48: Pushed
62d2656807e7: Pushed
e98542e84725: Pushed
e47f7503b5d3: Pushed
69923d7387b2: Pushed
a118867844a0: Pushed
4568910c2995: Layer already exists
26eafd96cbc2: Layer already exists
28a3fbb997db: Layer already exists
17efc79ac0fe: Layer already exists
c1874f32062c: Pushed
0b6859e9fff1: Layer already exists
11829b3be9c0: Layer already exists
dc8e1d8b53e9: Layer already exists
9d49e0bc68a4: Layer already exists
8e396a1aad50: Layer already exists
4551c4525f2b: Pushed
786f85e246fc: Pushed
1f15b778adc8: Pushed
20230222150644: digest: sha256:8f99dbe4d47eec5ee717daae4e752b0833f80b8943acb7210c4c8227392f33fb size: 5156

> Task :runners:google-cloud-dataflow-java:setupXVR

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerSetup
Launching Java expansion service @ 37079
Launching Python expansion service @ 39597

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava
$ CURRENT_DIRECTORY=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/go/test
$ TESTS=./test/integration/... ./test/regression
$ RUNNER=portable
$ TIMEOUT=3h
$ SIMULTANEOUS=3
$ GCS_LOCATION=gs://temp-storage-for-end-to-end-tests
$ GCS_SUBFOLDER=test5321
$ PROJECT=apache-beam-testing
$ DATAFLOW_PROJECT=apache-beam-testing
$ REGION=us-central1
$ trap exit_background_processes SIGINT SIGTERM EXIT
$ key=--pipeline_opts
$ case --pipeline_opts in
$ PIPELINE_OPTS=--kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.46.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.46.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:37079
$ key=--runner
$ case --runner in
$ RUNNER=dataflow
$ key=--project
$ case --project in
$ PROJECT=apache-beam-testing
$ key=--dataflow_project
$ case --dataflow_project in
$ DATAFLOW_PROJECT=apache-beam-testing
$ key=--region
$ case --region in
$ REGION=us-central1
$ key=--tests
$ case --tests in
$ TESTS=./test/integration/xlang ./test/integration/io/xlang/...
$ key=--sdk_overrides
$ case --sdk_overrides in
$ SDK_OVERRIDES=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222150644
$ cd /home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src
$ test -d sdks/go/test
$ command -v docker
/usr/bin/docker
$ docker -v
Docker version 20.10.23, build 7155243
$ command -v gcloud
/usr/bin/gcloud
$ gcloud --version
Google Cloud SDK 406.0.0
alpha 2022.10.17
beta 2022.10.17
bq 2.0.79
bundled-python3-unix 3.9.12
core 2022.10.17
gcloud-crc32c 1.0.0
gsutil 5.14
$ TMPDIR=/tmp/tmp.brd84Q8eCq
$ gcloud_ver=406.0.0
$ TAG=20230222-152024
$ CONTAINER=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
Using container us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk
$ ./gradlew :sdks:go:container:docker -Pdocker-repository-root=us.gcr.io/apache-beam-testing/jenkins -Pdocker-tag=20230222-152024
To honour the JVM settings for this build a single-use Daemon process will be forked. See https://docs.gradle.org/7.5.1/userguide/gradle_daemon.html#sec:disabling_the_daemon.
Daemon will be stopped at the end of the build 
Configuration on demand is an incubating feature.
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy UP-TO-DATE
> Task :buildSrc:pluginDescriptors UP-TO-DATE
> Task :buildSrc:processResources UP-TO-DATE
> Task :buildSrc:classes UP-TO-DATE
> Task :buildSrc:jar UP-TO-DATE
> Task :buildSrc:assemble UP-TO-DATE
> Task :buildSrc:spotlessGroovy UP-TO-DATE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.6
go1.19.6: already downloaded in /home/jenkins/sdk/go1.19.6
GOCMD=/home/jenkins/go/bin/go1.19.6
> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean
> Task :sdks:go:container:goPrepare UP-TO-DATE

> Task :sdks:go:container:goBuild
/home/jenkins/go/bin/go1.19.6 build -o ./build/target/linux_amd64/boot boot.go boot_test.go

> Task :sdks:go:container:skipPullLicenses
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

BUILD SUCCESSFUL in 22s
16 actionable tasks: 5 executed, 11 up-to-date

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

$ docker images
$ grep 20230222-152024
us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk         20230222-152024   6237164fd7c1   2 seconds ago       150MB
$ gcloud docker -- push us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-152024
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk]
11b1bc8b7c11: Preparing
92357cbd80f9: Preparing
724a358da4b2: Preparing
1749aa95495f: Preparing
58329c399251: Preparing
48e110deaecd: Preparing
5b3c6cb8773c: Preparing
8e396a1aad50: Preparing
48e110deaecd: Waiting
5b3c6cb8773c: Waiting
8e396a1aad50: Waiting
58329c399251: Pushed
92357cbd80f9: Pushed
1749aa95495f: Pushed
11b1bc8b7c11: Pushed
724a358da4b2: Pushed
8e396a1aad50: Layer already exists
5b3c6cb8773c: Pushed
48e110deaecd: Pushed
20230222-152024: digest: sha256:c45d0edb0bdbbab88490555f4909f01b112c8d11710873528f670ef150e8a95c size: 1990
$ OVERRIDE=--sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222150644
$ cd sdks/go
>>> RUNNING dataflow integration tests with pipeline options:  -p 3 -timeout 3h --runner=dataflow --project=apache-beam-testing --region=us-central1 --environment_type=DOCKER --environment_config=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-152024 --staging_location=gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test176 --temp_location=gs://temp-storage-for-end-to-end-tests/temp-validatesrunner-test/test176 --endpoint= --sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222150644 --kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.46.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.46.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:37079
$ 
System Go installation: /snap/bin/go is go version go1.16.15 linux/amd64; Preparing to use /home/jenkins/go/bin/go1.19.3
go1.19.3: already downloaded in /home/jenkins/sdk/go1.19.3
/home/jenkins/go/bin/go1.19.3 test -v ./test/integration/xlang ./test/integration/io/xlang/... -p 3 -timeout 3h --runner=dataflow --project=apache-beam-testing --region=us-central1 --environment_type=DOCKER --environment_config=us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-152024 --staging_location=gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test176 --temp_location=gs://temp-storage-for-end-to-end-tests/temp-validatesrunner-test/test176 --endpoint= --sdk_harness_container_image_override=.*java.*,us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222150644 --kafka_jar=/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/testing/kafka-service/build/libs/beam-sdks-java-testing-kafka-service-testKafkaService-2.46.0-SNAPSHOT.jar --expansion_jar=io:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/expansion-service/build/libs/beam-sdks-java-io-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=schemaio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/extensions/schemaio-expansion-service/build/libs/beam-sdks-java-extensions-schemaio-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=debeziumio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/debezium/expansion-service/build/libs/beam-sdks-java-io-debezium-expansion-service-2.46.0-SNAPSHOT.jar --expansion_jar=gcpio:/home/jenkins/jenkins-slave/workspace/beam_PostCommit_XVR_GoUsingJava_Dataflow/src/sdks/java/io/google-cloud-platform/expansion-service/build/libs/beam-sdks-java-io-google-cloud-platform-expansion-service-2.46.0-SNAPSHOT.jar --bq_dataset=apache-beam-testing.beam_bigquery_io_test_temp --expansion_addr=test:localhost:37079
FATAL: command execution failed
java.io.IOException: Backing channel 'apache-beam-jenkins-13' is disconnected.
	at hudson.remoting.RemoteInvocationHandler.channelOrFail(RemoteInvocationHandler.java:215)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:285)
	at com.sun.proxy.$Proxy138.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1215)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1207)
	at hudson.Launcher$ProcStarter.join(Launcher.java:524)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:814)
	at hudson.model.Build$BuildExecution.build(Build.java:199)
	at hudson.model.Build$BuildExecution.doRun(Build.java:164)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:522)
	at hudson.model.Run.execute(Run.java:1896)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:44)
	at hudson.model.ResourceController.execute(ResourceController.java:101)
	at hudson.model.Executor.run(Executor.java:442)
Caused by: java.io.IOException: Pipe closed after 0 cycles
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:126)
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:105)
	at hudson.remoting.FlightRecorderInputStream.read(FlightRecorderInputStream.java:94)
	at hudson.remoting.ChunkedInputStream.readHeader(ChunkedInputStream.java:75)
	at hudson.remoting.ChunkedInputStream.readUntilBreak(ChunkedInputStream.java:105)
	at hudson.remoting.ChunkedCommandTransport.readBlock(ChunkedCommandTransport.java:39)
	at hudson.remoting.AbstractSynchronousByteArrayCommandTransport.read(AbstractSynchronousByteArrayCommandTransport.java:34)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:61)
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-13 is offline; cannot locate jdk_1.8_latest

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1320

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1320/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Add retry logic to Python boot script.

[Robert Bradshaw] More verbose messaging.

[noreply] [#24789][prism] V0 Go Direct Runner Replacement, Prism. (#25568)


------------------------------------------
[...truncated 1016.84 KB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-083233",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222082046",
            "environmentId": "HptZCiSjvGbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-083233"
      }
    ]
  },
  "name": "go-testxlang_partition-108",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/22 09:17:27 Submitted job: 2023-02-22_01_17_27-1508925401650993922
2023/02/22 09:17:27 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-22_01_17_27-1508925401650993922?project=apache-beam-testing
2023/02/22 09:17:27 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-22_01_17_27-1508925401650993922
2023/02/22 09:17:27 Job state: JOB_STATE_PENDING ...
2023/02/22 09:17:57 Job still running ...
2023/02/22 09:18:27 Job still running ...
2023/02/22 09:18:57 Job still running ...
2023/02/22 09:19:28 Job still running ...
2023/02/22 09:19:58 Job still running ...
2023/02/22 09:20:28 Job still running ...
2023/02/22 09:20:58 Job still running ...
2023/02/22 09:21:28 Job still running ...
2023/02/22 09:21:58 Job still running ...
2023/02/22 09:22:28 Job still running ...
2023/02/22 09:22:58 Job still running ...
2023/02/22 09:23:28 Job still running ...
2023/02/22 09:23:58 Job still running ...
2023/02/22 09:24:28 Job still running ...
2023/02/22 09:24:58 Job still running ...
2023/02/22 09:25:28 Job still running ...
2023/02/22 09:25:58 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-22_01_17_27-1508925401650993922 failed
--- FAIL: TestXLang_Partition (549.71s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3200.486s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677054794938031251
--- FAIL: TestBigQueryIO_BasicWriteRead (5.66s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44359 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ojHXUdZksD"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ojHXUdZksD"}}  windowing_strategies:{key:"w0@ojHXUdZksD"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ojHXUdZksD"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ojHXUdZksD"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ojHXUdZksD"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677054794938031251\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ojHXUdZksD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44359 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ojHXUdZksD"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ojHXUdZksD"}}  windowing_strategies:{key:"w0@ojHXUdZksD"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ojHXUdZksD"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ojHXUdZksD"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ojHXUdZksD"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677054794938031251\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ojHXUdZksD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 53 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000257000})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000257000})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010ede0?, 0xc0000bd9f0?}, {0x1136f49, 0x39}, {0xc0000f00c0?, 0xa9be80?, 0x1?}, {0xc0003fcdc0, 0xf}, 0xc0001c9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010ed80?, 0xc0000bd9f0?}, {0xc00065e540, 0x52}, {0x1?}, {0xc0001c9ea8, 0x2, 0x7f436c07c308?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003fcdc0, 0xf}, {0xc00065e540, 0x52}, {0xeb9520, 0xc00066a290})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.691s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.044s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:992e521dfbc709442a41f7195d95dfc647acf3a5de0d31d35423acf8efe0966a
  Associated tags:
 - 20230222-083233
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-083233
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-083233].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:992e521dfbc709442a41f7195d95dfc647acf3a5de0d31d35423acf8efe0966a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222082046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:340a5afea24d78d4ce78c400287d6e1321edc32c793183e1fdc907ee49461507]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222082046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:340a5afea24d78d4ce78c400287d6e1321edc32c793183e1fdc907ee49461507])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:340a5afea24d78d4ce78c400287d6e1321edc32c793183e1fdc907ee49461507
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:340a5afea24d78d4ce78c400287d6e1321edc32c793183e1fdc907ee49461507].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222082046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8a9102d6aea7db947746e38db73915d0d1969696e41533528b1261fdf05a58e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222082046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8a9102d6aea7db947746e38db73915d0d1969696e41533528b1261fdf05a58e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8a9102d6aea7db947746e38db73915d0d1969696e41533528b1261fdf05a58e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8a9102d6aea7db947746e38db73915d0d1969696e41533528b1261fdf05a58e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 11s
216 actionable tasks: 152 executed, 52 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1319

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1319/display/redirect?page=changes>

Changes:

[noreply] Revert workers for java tests (#25579)

[noreply] remove unnecessary error check (#25576)

[noreply] Making the default BigQuery write disposition to be WRITE_APPEND

[noreply] [Python] Support loading of TF models with saved weights (#25496)

[noreply] Bump github.com/aws/aws-sdk-go-v2/config in /sdks (#25572)


------------------------------------------
[...truncated 1.03 MB...]
2023/02/22 03:41:03 Job still running ...
2023/02/22 03:41:34 Job still running ...
2023/02/22 03:42:04 Job still running ...
2023/02/22 03:42:34 Job still running ...
2023/02/22 03:43:04 Job still running ...
2023/02/22 03:43:34 Job still running ...
2023/02/22 03:44:04 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-21_19_35_32-15761086667881090688 failed
--- FAIL: TestXLang_Partition (549.96s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3263.714s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677034215160364138
--- FAIL: TestBigQueryIO_BasicWriteRead (5.62s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37107 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PJwFSRAMlq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PJwFSRAMlq"}}  windowing_strategies:{key:"w0@PJwFSRAMlq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PJwFSRAMlq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PJwFSRAMlq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PJwFSRAMlq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677034215160364138\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PJwFSRAMlq"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37107 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@PJwFSRAMlq"  is_bounded:BOUNDED  windowing_strategy_id:"w0@PJwFSRAMlq"}}  windowing_strategies:{key:"w0@PJwFSRAMlq"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@PJwFSRAMlq"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@PJwFSRAMlq"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@PJwFSRAMlq"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677034215160364138\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"PJwFSRAMlq"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00024d900})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00024d900})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169980?, 0xc00053f810?}, {0x1136f49, 0x39}, {0xc000236000?, 0xa9be80?, 0x1?}, {0xc0003f6d70, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169920?, 0xc00053f810?}, {0xc00010e840, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7efcecb64998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d70, 0xf}, {0xc00010e840, 0x52}, {0xeb9520, 0xc000130200})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000516ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000516ea0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.652s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.044s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-024910
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-024910
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cf741ff34e3ceda6754a07227622428b4c4474bee8483a0909eef4395f53ddc
Deleted: sha256:cae3f4ab69749f357b1b8980e5e7af210b244c521b5dd82611200dde0999003f
Deleted: sha256:b0c44d989c1ef39bad6fb339ea7aae059c7523789f8e05b8a448af5ed5d0cc22
Deleted: sha256:1e7bcec86dbde6e7340026cf35b0a8e58100ab2e22936ce1f6a3a40a8c139353
Deleted: sha256:55af5d71c38735bef02385f32237d97b9356902a72e705162c22797adc750dd1
Deleted: sha256:e8c7f4f31992e44efa0e829bc9be84733be703e7e364e2b3e391b38b0f4b4758
Deleted: sha256:6bb6d779fa15f745a74c5dd82e4f1a312bf176d8fd00e03c9d2fb9c43437f0f1
Deleted: sha256:962d5ce173bfb39af47a942251e150a4525cdef13940793a7cd7aa586e77a0ed
Deleted: sha256:c607bc3686e7286b09e7b9e35e0fd4c81bad535ea3ca66960131c2ea359ed803
Deleted: sha256:e8ed621aa29f16df9d9eba2d3b94c0f8136da90d6789cdd9b8795faea568125b
Deleted: sha256:3920de29479668d58410c9ef58591196f0be9dbe5ebcc97823b5393098217f15
Deleted: sha256:0ca5bd714886a0cfef7904c46a287cff90d90b61542b72bb413b47b2f89cf6c1
Deleted: sha256:44d3f7dd12b1190ec47b0bfe598b0c8f6b6dbbef7c360d1f069cd008c04dfcfa
Deleted: sha256:2f4d23f315365054fa2a18f44bb483b01a883f33814007bc3f5b622df180217d
Deleted: sha256:741c27e09051dfe6ebea8a2f087e23b00b85e0e5c2f67bb7f57ac26364371f69
Deleted: sha256:ce68f4c29cc2c33cc01db087fb0f2f8d4bbe5eefb4ae7aedc290578a4c93bf76
Deleted: sha256:8f5b804c1ee58556d5d1f7bb5dae225c4485a6e2d90239399a22d58d6436f222
Deleted: sha256:79922d8cc4e7f76568542557afe2f837f309af01cffd0933a999bc900c3f0eda
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-024910
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cf741ff34e3ceda6754a07227622428b4c4474bee8483a0909eef4395f53ddc
  Associated tags:
 - 20230222-024910
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-024910
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230222-024910].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2cf741ff34e3ceda6754a07227622428b4c4474bee8483a0909eef4395f53ddc].
$ rm -rf /tmp/tmp.DhWxNARPoW
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222023705
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222023705]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230222023705] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9bf8cd5026109065d6db7fd42957bdc898c2d6c88e408993326838850eec7899].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222023705
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131
Deleted: sha256:bde56dcbc4ca02e854d1410d885e0e5f7b0498514cc93a8aff9687cc9508e988
Deleted: sha256:3c958a028e54042b1eea525e7f755567cb3bd8e381b456648c209b7ef1b34632
Deleted: sha256:c3b4c3596f60eb084e50887347969451ac15d556dfd02a5b095fb636d226ba80
Deleted: sha256:08c44734804635d18d311cec11458a73ae9633ce85baba61504adab4f64c4c11
Deleted: sha256:60fc7911672d5c509eef9b7acb951c72022b30ac2f7ca69742ded32007ca11f1
Deleted: sha256:30defc08dd05e599650ec0a6f621455e381f2c7ff8bb10d878e5013e3fef84c5
Deleted: sha256:f4e260105dc611c155e7058b3f50c3e31d766acf268558c000d3bca6010986ad
Deleted: sha256:5757db051e4113b8d556d004860eca74844af97e6b9b8cde5c0d09ffd2588861
Deleted: sha256:26f3383343e90ab096bd017104b2e02f0944fb7a3b7c87eb7148e4941bec7890
Deleted: sha256:0bda5c69a40d83445cf9614834b2609c0205644789c4e23512427a267e9d2c1e
Deleted: sha256:76f422e872fe838ac4210b3b07d45768fc7a4fc35c570bf6722c57c250503c59
Deleted: sha256:2286166eceebb4b41fc81d6f9e6363a92f359f4992552db67d3c2e462d02017f
Deleted: sha256:382f377a94a8d40489e51dfd1c91641cd44042092e6f8fb3f2897bf49c204e1e
Deleted: sha256:bc633eec7d7eacacff896c61bf611f81323e44cffcca1eab3cdd3e29ceb04504
Deleted: sha256:69e1c1d1f468b9769df0292c2ac15c687934a03c7b97a26be95d6bab50de89f0
Deleted: sha256:8fb648b9344d85d5d388779d513f4ce701e1c6d16bae62bded2e26453a9816ee
Deleted: sha256:271975378ffbd44d5ccbbe3a1dd275350dcd9f0bc3bc215f5c4e857c74aff34a
Deleted: sha256:c7d8ae0341dd5e933b833bcc1f68d4bfecab6225398ff5f9b1c52e414490861c
Deleted: sha256:aa7b7ae96347006c32bcd41773fbd79bfed413c102ea5c09d7e32e6015925e46
Deleted: sha256:5e80c361b8f4af28f59044853cfb476b58406f0fbb603553b40b90c057f1b634
Deleted: sha256:70fc512c55fbe4a3bcb13b113f16ed38aaccae50cd398a2b28ba7b4473faf7e7
Deleted: sha256:fd2a226ee6788061d61bdd5a07d10073255d339eeb45d89605db52f3e3b408ba
Deleted: sha256:eb16744d95c31f3131bc2da21d3514ee8b3419f63eb80c3f2840c2975f1bb9f1
Deleted: sha256:d11de4654de132f8670173549a4a42619368bfeba09aaf3b63891955208c3529
Deleted: sha256:a5a5201edb40daa9ad347c62e41edaa134adbfa98e736cfd040f44d688681354
Deleted: sha256:1e381ae935b4978180bb26c3dcca82bbd6bbf2c6821971a15ee995b598a262cf
Deleted: sha256:1a8b85df4a30fae9ad1515ae64cc5a4269e80709caa1fcf66275bd6b041d2027
Deleted: sha256:e9469f7add57db5b349f95663c67972f783fc1ffc5be8429afbe9a9bbddf4e9e
Deleted: sha256:011e63294b7fd06d611f5fa7330606480960581a092a798c408daf66426d49d8
Deleted: sha256:3de4f8ae914adaec357b68ef28f70d6dd125fb2af243436eea9f8448853dde0c
Deleted: sha256:32bfa53b2c1910568f55225082e1bdbbcbb771156d0b9a7dc2254178b78b135b
Deleted: sha256:ab0e88b25178dc08b45748baa442e65e0a9c6cb806e44673dd280c5c58935102
Deleted: sha256:6e48827814eee4e7559eae065e264bb90e644b0063078ff3fa19963bc73e8bb5
Deleted: sha256:568a85fe78d9538f4a1d203b2b4059b8e90572386cd76fc6d689ef3f083e6a66
Deleted: sha256:d99eb754f29bfa718c1469297cd443ab91a7845905cf31afe7ec5ef7cc2132ba
Deleted: sha256:0d49a85904140032e4486a58ca1f89fa89483b27e93371536bcaa72116ba358a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222023705]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230222023705] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9eb0674cabce8764107206ee7ebb916cb3d1c1d5b5825af814727fe69b2d9131].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3436639.
Stopping expansion service pid: 3436640.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 56s
216 actionable tasks: 159 executed, 45 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1318

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1318/display/redirect?page=changes>

Changes:

[noreply] Better error for missing timezone info (#25444)

[noreply] Revert "Replace more uses of `ClassLoadingStrategy.Default.INJECTION`

[noreply] Use context param and error return value in mongodbio.Read SDF methods


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-211458",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221210008",
            "environmentId": "LmnRqiXgKnbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-211458"
      }
    ]
  },
  "name": "go-testxlang_partition-378",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/21 21:58:32 Submitted job: 2023-02-21_13_58_32-9568557412754803167
2023/02/21 21:58:32 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-21_13_58_32-9568557412754803167?project=apache-beam-testing
2023/02/21 21:58:32 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-21_13_58_32-9568557412754803167
2023/02/21 21:58:32 Job state: JOB_STATE_PENDING ...
2023/02/21 21:59:02 Job still running ...
2023/02/21 21:59:32 Job still running ...
2023/02/21 22:00:02 Job still running ...
2023/02/21 22:00:32 Job still running ...
2023/02/21 22:01:02 Job still running ...
2023/02/21 22:01:33 Job still running ...
2023/02/21 22:02:03 Job still running ...
2023/02/21 22:02:33 Job still running ...
2023/02/21 22:03:03 Job still running ...
2023/02/21 22:03:33 Job still running ...
2023/02/21 22:04:03 Job still running ...
2023/02/21 22:04:33 Job still running ...
2023/02/21 22:05:03 Job still running ...
2023/02/21 22:05:33 Job still running ...
2023/02/21 22:06:03 Job still running ...
2023/02/21 22:06:33 Job still running ...
2023/02/21 22:07:03 Job still running ...
2023/02/21 22:07:33 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-21_13_58_32-9568557412754803167 failed
--- FAIL: TestXLang_Partition (579.28s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3145.672s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677014148631537466
--- FAIL: TestBigQueryIO_BasicWriteRead (5.93s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45763 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@EZRHolSTXf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@EZRHolSTXf"}}  windowing_strategies:{key:"w0@EZRHolSTXf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@EZRHolSTXf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@EZRHolSTXf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@EZRHolSTXf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677014148631537466\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"EZRHolSTXf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45763 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@EZRHolSTXf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@EZRHolSTXf"}}  windowing_strategies:{key:"w0@EZRHolSTXf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@EZRHolSTXf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@EZRHolSTXf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@EZRHolSTXf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1677014148631537466\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"EZRHolSTXf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000113840})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000113840})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0006aad20?, 0xc0005a1630?}, {0x1136f49, 0x39}, {0xc00015e0c0?, 0xa9be80?, 0x1?}, {0xc00069ccd0, 0xf}, 0xc0005f5d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0006aacc0?, 0xc0005a1630?}, {0xc00059e300, 0x52}, {0x1?}, {0xc0005f5ea8, 0x2, 0x7f91f5fbfe30?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00069ccd0, 0xf}, {0xc00059e300, 0x52}, {0xeb9520, 0xc00069dfe0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000d8820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000d8820, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.962s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.042s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.041s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19711a5be8a4de657328524b9f7119d7589e464b7e5211a790c974f1c34cd537
  Associated tags:
 - 20230221-211458
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-211458
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-211458].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:19711a5be8a4de657328524b9f7119d7589e464b7e5211a790c974f1c34cd537].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221210008]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2a663a74ba689980a8adb46db799b8b9fda862e85dcaea78cf161607a34abfc1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221210008] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2a663a74ba689980a8adb46db799b8b9fda862e85dcaea78cf161607a34abfc1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2a663a74ba689980a8adb46db799b8b9fda862e85dcaea78cf161607a34abfc1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2a663a74ba689980a8adb46db799b8b9fda862e85dcaea78cf161607a34abfc1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221210008]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c3aaa3100445d1f2c4b84581fe7be46bccc2b4cee3d8e80cae1a67481547d2a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221210008] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c3aaa3100445d1f2c4b84581fe7be46bccc2b4cee3d8e80cae1a67481547d2a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c3aaa3100445d1f2c4b84581fe7be46bccc2b4cee3d8e80cae1a67481547d2a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c3aaa3100445d1f2c4b84581fe7be46bccc2b4cee3d8e80cae1a67481547d2a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 21s
216 actionable tasks: 172 executed, 32 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1317

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1317/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-143231",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221142045",
            "environmentId": "aIeJGOGpTKbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-143231"
      }
    ]
  },
  "name": "go-testxlang_partition-765",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/21 15:18:11 Submitted job: 2023-02-21_07_18_10-16364616298029721827
2023/02/21 15:18:11 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-21_07_18_10-16364616298029721827?project=apache-beam-testing
2023/02/21 15:18:11 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-21_07_18_10-16364616298029721827
2023/02/21 15:18:11 Job state: JOB_STATE_PENDING ...
2023/02/21 15:18:41 Job still running ...
2023/02/21 15:19:11 Job still running ...
2023/02/21 15:19:41 Job still running ...
2023/02/21 15:20:11 Job still running ...
2023/02/21 15:20:41 Job still running ...
2023/02/21 15:21:11 Job still running ...
2023/02/21 15:21:41 Job still running ...
2023/02/21 15:22:11 Job still running ...
2023/02/21 15:22:41 Job still running ...
2023/02/21 15:23:11 Job still running ...
2023/02/21 15:23:41 Job still running ...
2023/02/21 15:24:11 Job still running ...
2023/02/21 15:24:41 Job still running ...
2023/02/21 15:25:11 Job still running ...
2023/02/21 15:25:41 Job still running ...
2023/02/21 15:26:11 Job still running ...
2023/02/21 15:26:41 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-21_07_18_10-16364616298029721827 failed
--- FAIL: TestXLang_Partition (549.30s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3238.698s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676989999365791487
--- FAIL: TestBigQueryIO_BasicWriteRead (5.68s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45121 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ABFvjXVvmS"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ABFvjXVvmS"}}  windowing_strategies:{key:"w0@ABFvjXVvmS"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ABFvjXVvmS"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ABFvjXVvmS"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ABFvjXVvmS"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676989999365791487\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ABFvjXVvmS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45121 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ABFvjXVvmS"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ABFvjXVvmS"}}  windowing_strategies:{key:"w0@ABFvjXVvmS"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ABFvjXVvmS"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ABFvjXVvmS"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ABFvjXVvmS"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676989999365791487\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ABFvjXVvmS"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 23 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000237e80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000237e80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048cf80?, 0xc0001478b0?}, {0x1136f49, 0x39}, {0xc00022c000?, 0xa9be80?, 0x1?}, {0xc000043de0, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048cf20?, 0xc0001478b0?}, {0xc000534360, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0x7f2dd4d00240?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043de0, 0xf}, {0xc000534360, 0x52}, {0xeb9520, 0xc00013b100})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000462ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000462ea0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.708s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ad53a7f77cdab4f28d66e3f76bba057cc4aec53bdd78af88a25a55a445ee453c
  Associated tags:
 - 20230221-143231
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-143231
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-143231].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ad53a7f77cdab4f28d66e3f76bba057cc4aec53bdd78af88a25a55a445ee453c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e0981a8748f1c25c8628e0706ee68c074d006f02a4440c5a07bc80963875a9a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e0981a8748f1c25c8628e0706ee68c074d006f02a4440c5a07bc80963875a9a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e0981a8748f1c25c8628e0706ee68c074d006f02a4440c5a07bc80963875a9a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7e0981a8748f1c25c8628e0706ee68c074d006f02a4440c5a07bc80963875a9a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7700ef160e056350b0c39d460dcb2356c6c69dcea7e774be3aac7d0ed2e590ca]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7700ef160e056350b0c39d460dcb2356c6c69dcea7e774be3aac7d0ed2e590ca])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7700ef160e056350b0c39d460dcb2356c6c69dcea7e774be3aac7d0ed2e590ca
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7700ef160e056350b0c39d460dcb2356c6c69dcea7e774be3aac7d0ed2e590ca].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 52s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1316

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1316/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221082050",
            "environmentId": "RtZXUPHkBVbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216"
      }
    ]
  },
  "name": "go-testxlang_partition-443",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/21 09:16:52 Submitted job: 2023-02-21_01_16_52-8474446086724386332
2023/02/21 09:16:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-21_01_16_52-8474446086724386332?project=apache-beam-testing
2023/02/21 09:16:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-21_01_16_52-8474446086724386332
2023/02/21 09:16:52 Job state: JOB_STATE_PENDING ...
2023/02/21 09:17:22 Job still running ...
2023/02/21 09:17:53 Job still running ...
2023/02/21 09:18:23 Job still running ...
2023/02/21 09:18:53 Job still running ...
2023/02/21 09:19:23 Job still running ...
2023/02/21 09:19:53 Job still running ...
2023/02/21 09:20:23 Job still running ...
2023/02/21 09:20:53 Job still running ...
2023/02/21 09:21:23 Job still running ...
2023/02/21 09:21:53 Job still running ...
2023/02/21 09:22:23 Job still running ...
2023/02/21 09:22:53 Job still running ...
2023/02/21 09:23:23 Job still running ...
2023/02/21 09:23:53 Job still running ...
2023/02/21 09:24:23 Job still running ...
2023/02/21 09:24:53 Job still running ...
2023/02/21 09:25:23 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-21_01_16_52-8474446086724386332 failed
--- FAIL: TestXLang_Partition (551.37s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3182.203s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676968374751764211
--- FAIL: TestBigQueryIO_BasicWriteRead (4.42s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35353 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dSgRasVlXf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dSgRasVlXf"}}  windowing_strategies:{key:"w0@dSgRasVlXf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dSgRasVlXf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dSgRasVlXf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dSgRasVlXf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676968374751764211\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dSgRasVlXf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35353 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@dSgRasVlXf"  is_bounded:BOUNDED  windowing_strategy_id:"w0@dSgRasVlXf"}}  windowing_strategies:{key:"w0@dSgRasVlXf"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@dSgRasVlXf"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@dSgRasVlXf"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@dSgRasVlXf"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676968374751764211\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"dSgRasVlXf"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 36 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0003f8700})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0003f8700})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168ba0?, 0xc000570000?}, {0x1136f49, 0x39}, {0xc00057a0c0?, 0xa9be80?, 0x1?}, {0xc00049ed70, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168b20?, 0xc000570000?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00049ed70, 0xf}, {0xc00004c4e0, 0x52}, {0xeb9520, 0xc0000421c8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000556b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000556b60, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.456s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2828cc48aedf68c4a1afbb448f388af984df86d6261795f259a49080b53469fa
Deleted: sha256:cb545945b91e6127799632a89b6a60bb84f5b2ee06f6e73dbffaefaa2a327539
Deleted: sha256:0b82fbf53a07b434ce12f95fa514388fdef63999910fff422316eb3b8a5472b0
Deleted: sha256:f04524a32646f7714aef0a3889d5e955c207c0bff8c09af25af680f5817bb6a2
Deleted: sha256:0cdca93630beaa8dec2527a26d479c545deaf3da50f74119fe8cbc434b57b085
Deleted: sha256:cc24b9fccd5f95df29e400f07a20e2c98f7fd9818f3a75a26a5f51f71b1a1515
Deleted: sha256:7efbef8b6a635415413b45185548c6efda21fef22bedfccc3c4c6f30a00af6b2
Deleted: sha256:5af2e16e36c2f8d5301e688c34cb1e0ad7235a3aabea9a8ceb80b73f8df94bfe
Deleted: sha256:e0e8869ceba0d81da1d8dbc7bcf0d6c43f63888af779f1446bf7a15ffff66220
Deleted: sha256:e09f1ba15b902f9389c98390e875416a6cf73b473e6c3b77e231499da21bf4d1
Deleted: sha256:de8775afd240c0f77af47ee72174cb9ec730b38395855538bdb805c82a1cb5d8
Deleted: sha256:d6d731de7266fdca5dba73fcde8d7e92c645060d5db02647f019dc17d953b8ed
Deleted: sha256:fe33e22a159c9c04358aff5cfae954c475a4b92dffb779f089916ef6cfc2b8ca
Deleted: sha256:7bbefcb5151a99734c432a30cd4ff7210ce5be9388003ba083d6a1c73028324a
Deleted: sha256:9c09213adfd1f19089c896e357155df79d9231777155744e5d044585cb727cc2
Deleted: sha256:124bcea2b25a25ed6439df5d24885abca15af128a09b0399efb1dec3b72d3e55
Deleted: sha256:17e74508fb5f504d07dc46a40e3a208273d1bfc2f5bfee38a782f255b1503edc
Deleted: sha256:e79ac6c37668dc78a9a7a5e2a2225cfa7b769c3292a390e6b9ecc9705178a26a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2828cc48aedf68c4a1afbb448f388af984df86d6261795f259a49080b53469fa
  Associated tags:
 - 20230221-083216
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-083216].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2828cc48aedf68c4a1afbb448f388af984df86d6261795f259a49080b53469fa].
$ rm -rf /tmp/tmp.NiYpRcVzeV
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3624f7801aa2ce57f06c7c6bfaef9acdf84fb17535425768413e1524dbb01a5e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:3e99fa73dda7c2711f66e2e6e9a33815f28eaa93c9b359134f7b18849504558b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1204048.
Stopping expansion service pid: 1204049.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 43s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1315

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1315/display/redirect?page=changes>

Changes:

[noreply] [prism] Add in element manager (#25565)


------------------------------------------
[...truncated 1.01 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221022048",
            "environmentId": "YtnbmCSuGfbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153"
      }
    ]
  },
  "name": "go-testxlang_partition-381",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/21 03:14:42 Submitted job: 2023-02-20_19_14_41-17869256744608469201
2023/02/21 03:14:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-20_19_14_41-17869256744608469201?project=apache-beam-testing
2023/02/21 03:14:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-20_19_14_41-17869256744608469201
2023/02/21 03:14:42 Job state: JOB_STATE_PENDING ...
2023/02/21 03:15:12 Job still running ...
2023/02/21 03:15:42 Job still running ...
2023/02/21 03:16:12 Job still running ...
2023/02/21 03:16:42 Job still running ...
2023/02/21 03:17:12 Job still running ...
2023/02/21 03:17:42 Job still running ...
2023/02/21 03:18:12 Job still running ...
2023/02/21 03:18:42 Job still running ...
2023/02/21 03:19:12 Job still running ...
2023/02/21 03:19:42 Job still running ...
2023/02/21 03:20:12 Job still running ...
2023/02/21 03:20:42 Job still running ...
2023/02/21 03:21:12 Job still running ...
2023/02/21 03:21:43 Job still running ...
2023/02/21 03:22:13 Job still running ...
2023/02/21 03:22:43 Job still running ...
2023/02/21 03:23:13 Job still running ...
2023/02/21 03:23:43 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-20_19_14_41-17869256744608469201 failed
--- FAIL: TestXLang_Partition (579.13s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3105.692s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676946753167921065
--- FAIL: TestBigQueryIO_BasicWriteRead (5.56s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42077 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZedpEExoxd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZedpEExoxd"}}  windowing_strategies:{key:"w0@ZedpEExoxd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZedpEExoxd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZedpEExoxd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZedpEExoxd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676946753167921065\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZedpEExoxd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42077 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@ZedpEExoxd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@ZedpEExoxd"}}  windowing_strategies:{key:"w0@ZedpEExoxd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@ZedpEExoxd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@ZedpEExoxd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@ZedpEExoxd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676946753167921065\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"ZedpEExoxd"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000470380})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000470380})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048a9c0?, 0xc00012e1e0?}, {0x1136f49, 0x39}, {0xc0000ee180?, 0xa9be80?, 0x1?}, {0xc00012ad30, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048a960?, 0xc00012e1e0?}, {0xc00053c3c0, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00012ad30, 0xf}, {0xc00053c3c0, 0x52}, {0xeb9520, 0xc000482588})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103ba0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.590s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.042s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:095ee89d86375521487dc0336e9502ef0885c673a30fa7ede74d3f263446a4e1
Deleted: sha256:9b740dd962fa7b0a9b71cf2310bb9606566bd5039615a040340d0182071a6c85
Deleted: sha256:e661c8f5998409a740277a486776195340fca931c08144bb12b95845e9fa5f27
Deleted: sha256:2b6e3c702b8ab7279948e3386ba027f7462a39355693ff001c5880b017462a3c
Deleted: sha256:469bc41a115dc841efc1d0ed9ce487f0457941eeb0d4c722f903c3cbbac1792b
Deleted: sha256:bc99a7f2c85ac2356fcc79a27ff3a8e7c7a98f634709c27315818ee9534183f1
Deleted: sha256:4af3e979903a1b25b27365d022564db933436ddcf847b00eb766e559ad23c753
Deleted: sha256:bc64f5a6e6b0578dbef017f3cd336b2b7a8d5db147c04afaeaa585a959eb1fc6
Deleted: sha256:40d88544e0882ce00f5579646c709c04250bf066e05e4c9f027422f9e2d82ad6
Deleted: sha256:f0777531ba7d3b196f6820996c97027b0e4166bc02a0f2c29ca6ebc3243e7a66
Deleted: sha256:fe33366719e5f7942e8665c27879fa5c3da3a296dd59fb2f0a64e4dc70ebaba9
Deleted: sha256:750fedfdb6c402390624937415b3284164f24951152bed0a1fc4092eb0467964
Deleted: sha256:514b52a1edfe7d0b8849040217332de0afbcdc3b0e70f9d6719aad816256397f
Deleted: sha256:c0c405fd99e2637920fb770fd6bc695406ad6fc6b0c588cdd433ff6f22cf1b2d
Deleted: sha256:d28c0ac13e451fbc4ad3ee2fb3c5b4e90db3ffe313417b2b5cf213bc0831601f
Deleted: sha256:03ed6b5a6c218bffbae16fa95e5378cbab04868e3144e908c7b37ee69b19c948
Deleted: sha256:478fc65124208484488c968eb76ed0bc2cf92e662b8074097a7e220935d7ed99
Deleted: sha256:d7f2e70cabd3ce6e102cc42b7fa76093cec92a40cf0e5ec6972bc13a3e1e1d4c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:095ee89d86375521487dc0336e9502ef0885c673a30fa7ede74d3f263446a4e1
  Associated tags:
 - 20230221-023153
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230221-023153].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:095ee89d86375521487dc0336e9502ef0885c673a30fa7ede74d3f263446a4e1].
$ rm -rf /tmp/tmp.OP1mj0Sc58
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221022048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230221022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c4478511aed1abddba5f9c78be6353b0f231405cfe163bd3fe93f30c7daefd29].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221022048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230221022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:07638fb1ff9ec786e664537c3e875445d81a5cb220a3a4763f7e81038f46444d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1064306.
Stopping expansion service pid: 1064307.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 3m 51s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1314

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1314/display/redirect?page=changes>

Changes:

[noreply] [#24789][prism] Add testdofns for later (#25557)

[noreply] [#24789][prism] Minimum required jobservices (#25556)

[noreply] [#24789][prism] Handlers for combine, ParDo, GBK, Flatten  (#25558)

[noreply] [prism] Tiny lint fixes (#25564)

[noreply] minor error handling fixes (#25555)


------------------------------------------
[...truncated 772.59 KB...]
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000336be0?, 0xc000138e10?}, {0xf0a0a1, 0x20}, {0x0?, 0xd28e80?, 0x2?}, {0x7fff2aa55462, 0xf}, 0xc000805ca0, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/examples/xlang.CombineGlobally({0xc000336b20?, 0xc000138e10?}, {0x7fff2aa55462, 0xf}, {0x527ac0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/examples/xlang/transforms.go>:74 +0x305
github.com/apache/beam/sdks/v2/go/test/integration/xlang.TestXLang_CombineGlobally(0xc0002209c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/xlang/xlang_test.go>:180 +0x171
testing.tRunner(0xc0002209c0, 0xf53f68)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	1189.645s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676927070223244281
--- FAIL: TestBigQueryIO_BasicWriteRead (6.11s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40307 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@FTfjVEHcrI"  is_bounded:BOUNDED  windowing_strategy_id:"w0@FTfjVEHcrI"}}  windowing_strategies:{key:"w0@FTfjVEHcrI"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@FTfjVEHcrI"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@FTfjVEHcrI"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@FTfjVEHcrI"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676927070223244281\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"FTfjVEHcrI"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40307 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@FTfjVEHcrI"  is_bounded:BOUNDED  windowing_strategy_id:"w0@FTfjVEHcrI"}}  windowing_strategies:{key:"w0@FTfjVEHcrI"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@FTfjVEHcrI"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@FTfjVEHcrI"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@FTfjVEHcrI"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676927070223244281\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"FTfjVEHcrI"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000506d80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000506d80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a77a0?, 0xc000727680?}, {0x1136f49, 0x39}, {0xc00017c0c0?, 0xa9be80?, 0x1?}, {0xc00050ac90, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7720?, 0xc000727680?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7ff95c4247f0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00050ac90, 0xf}, {0xc00004ca80, 0x52}, {0xeb9520, 0xc00050bfa0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00051b040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00051b040, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.142s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.044s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-210334
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-210334
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:356478df19e85ddfc861dc85e76e64ec48d1f0a63358b49b0d70c28417c117a1
Deleted: sha256:7548fd518f8361bca6c9a587aafdac721fbf8ffce152d1eb280fe0a3d687c9b3
Deleted: sha256:7c7c8caabbd07767a577977cfec32b700a02c5acb8fe27413dc261af3e64f491
Deleted: sha256:55a363101ae1e6963964264f3b98955217ae3b97ec20112ae66956286275329f
Deleted: sha256:40c8478ddda5442a7e488b4a3245d4a43dbe11003650d9a528ac12adbb6dffaf
Deleted: sha256:068e9590cc13d925cbfc2053ab0e16910c9e2788e0ec7f23b88c2f44994acb88
Deleted: sha256:325967d7604d9931a2b90f81c3823d17b6d72e0a614b56aaa734b1f3d15d7c9b
Deleted: sha256:0fa04f042ed677a66cb3893459c0bd871af74395c6fe223d58909512cf21fd7f
Deleted: sha256:f6a5736dea0102d5bad2f1ae4edd70c0902f46ac13c160690052d39d676b9915
Deleted: sha256:24268b6454cbf40bfd887817d6975734169f65fe0bd16f6ca1e26a455cd2f8e4
Deleted: sha256:349a249f0ac596960921c09518cf078c169210177a4c943814c968604854f5bf
Deleted: sha256:87f9ed44cc935aa1fc01c227dace38b6e693a6362fb6bba0c141610ce2ae6a72
Deleted: sha256:90fbb22e84ab1a8943f534d89f0d733646c9c273ef4329ea80b687ab7da61335
Deleted: sha256:563d8a59958ee44483ac46c92c4366841913b6888ad567ff3f5efe559ec64e66
Deleted: sha256:dce70116601754be7f6511230c2c18d157c606e03f3538f1d228c161e050c38b
Deleted: sha256:44c5679e89af10fee763ef91ee93e572a35b4633c6a5894b9915928260e7712d
Deleted: sha256:2fbf6ce0e010f1bfd54d8bf27992944d43828a360737125d90debaff3a9ad3d2
Deleted: sha256:9d893b6555ac4eb638271de74a38a30366fbebaf6a92a943c91d66bf2cd2172c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-210334
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:356478df19e85ddfc861dc85e76e64ec48d1f0a63358b49b0d70c28417c117a1
  Associated tags:
 - 20230220-210334
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-210334
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-210334].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:356478df19e85ddfc861dc85e76e64ec48d1f0a63358b49b0d70c28417c117a1].
$ rm -rf /tmp/tmp.gQoDsS56aA
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220204900
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220204900]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220204900] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:59420d80fe01b042b321c0eab028fa5a93640454e7a99cdc6d07039717e044a1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220204900
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69
Deleted: sha256:2c842d4d2faea5049207d41a57291af286c0896010b3702c3480e7fac7de6ede
Deleted: sha256:8f8e157331b3bca12a3104ca77ca6451ae0c67b16895300cdb4dbce36efd0c51
Deleted: sha256:05ac1342439e4bfc4a4338f41caafc9831a302cd2949e25fa59e5e639bc90afb
Deleted: sha256:5075151a09ca486f20c639f3130760f0ec3b14da70777276cc94d38ebbd7e5d3
Deleted: sha256:b4ff3d9b472cef293058078a21ecfefe83d9567b3a94475544ed737ea65feb9c
Deleted: sha256:349f9679a06fcd354e2f94c96377a18307cc5bb560a835181c2666ed0691fc68
Deleted: sha256:02e61a3b3433fced77014ec21c8a2a115aae3ad72a2d3ebdb057eeafa20e72d7
Deleted: sha256:10cfade79f4f27b6e37ac7961748afa8c02ad8e42938129b13ea031a68e6068e
Deleted: sha256:d888b3d4ffaa4ea8ba430c0dfac2a370e13541d56acbd328be1b3728915f0aa9
Deleted: sha256:9bda1bba6cfcc45692712d9357b77bba8ab77602aa54c2496bef3aa1d11f49d0
Deleted: sha256:3b8589a72f84715b2ac951929bab97ad1ceccd44db109f4a6f079e49d5a1c7e7
Deleted: sha256:8bc270d1401e7aa27701dd75c857742ad90e20f154d94f78eba18c2229b6cad2
Deleted: sha256:9f559fce821d35f60984593f277f19af40b1300fccd540f693dbd1e7afb2c486
Deleted: sha256:68bb7a2aa57f6c8cc9dad6b1728cb3fd201af23cf9fb000e2d96600fb02c0dca
Deleted: sha256:1d2f5129c43e0442a89396aa050fba977ab6c0dcf58db5e3bacd1c8d648fc483
Deleted: sha256:1645b2c5b8871bf2429adf2c86bf900ade09e1cbee77affa90ef47bf73685c05
Deleted: sha256:8fe2ceddcbbbc3b6196f8d9242ae7e866385cb708f4bc04bbb1fcaf8b5765a9e
Deleted: sha256:450e11f02ab670340b00cded7937529629800b4e511444e10d703e15822269db
Deleted: sha256:cdcf64ab05fd3dfe73be75437a4a178133c05b2bf3295efa28f358753fedc2b5
Deleted: sha256:8fd915a9d0df10c7964545e1e9e2eb1fc4f611ed5cef9cbcb42eaed9e09a2e94
Deleted: sha256:a5f9fecf6688da1588f63521be195b9d0562d8b427f0023438a4035e38e2b1a2
Deleted: sha256:33b8407bb389ddf781e93014fe94082c9cd2868d4682e0e27a786e4b24cf24a4
Deleted: sha256:06ed751bbe8989c211c834cb60357f9a7db0abb1297e4d05a03cd3d3a5914f2b
Deleted: sha256:9a3976c5edd279e2c6570fa2beb9aaf52be5f3ddfec2f156f51229803fe10553
Deleted: sha256:9da4d84eac834b03ad829de4190e7146afae163a7d5d30b563f32de9eaa6c4cc
Deleted: sha256:8612fc14659a9e4885c7f8f05050987d76d6bc6b4e33f01b525809f62d583655
Deleted: sha256:5a00a4a9cf66a346ded4cda41d0a51f45b5260bb04f4daba3685f2ff0167cd13
Deleted: sha256:499e87dc8631134d7a9b6ec25e214150a3b12421e0b7b31cc5e1873a00dabf5e
Deleted: sha256:803364987bf0f8b01369e47c03867d32b070eb06b71e8f67c11bb5170741e25a
Deleted: sha256:88807aa9c4d09f494b646bfa7cd452cb72ab690a63d54683455304fe8aa299d2
Deleted: sha256:f9e80fdcc30af877672e2a752f4b90794c3b2d9bd1caeb203124ea60c323a6a2
Deleted: sha256:418b89f8124bc61c5ee192d51c121e8fa37c580c6670935ff633ece2c6c8021c
Deleted: sha256:58483b7a631fa88b21964698ac2cb8330d9086fcd331140ccd4d012d82d02498
Deleted: sha256:0fb7f6f1b15a96b0143a7e8b803063c4ee1f14c4dbc1bbd042957844bee9cf9c
Deleted: sha256:a57108f9fabc5f9ddfda00404b2d0914fcd8bbd1b91f2bfefe6154e120a9190f
Deleted: sha256:c2f014ea7260a1c34b7a7b47ea6790a50d2774805178bd008af782a4a74a442c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220204900]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220204900] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a92202ea42f4d72380f50f2cb26ec063f44fb33306cf9fd7364fb0cd6b7b5a69].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 472031.
Stopping expansion service pid: 472032.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 35m 49s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1313

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1313/display/redirect>

Changes:


------------------------------------------
[...truncated 558.61 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-151922",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220150732",
            "environmentId": "HZDerjyoaUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-151922"
      }
    ]
  },
  "name": "go-testxlang_partition-154",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/20 16:04:55 Submitted job: 2023-02-20_08_04_55-11675659217827092535
2023/02/20 16:04:55 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-20_08_04_55-11675659217827092535?project=apache-beam-testing
2023/02/20 16:04:55 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-20_08_04_55-11675659217827092535
2023/02/20 16:04:55 Job state: JOB_STATE_PENDING ...
2023/02/20 16:05:26 Job still running ...
2023/02/20 16:05:56 Job still running ...
2023/02/20 16:06:26 Job still running ...
2023/02/20 16:06:56 Job still running ...
2023/02/20 16:07:26 Job still running ...
2023/02/20 16:07:56 Job still running ...
2023/02/20 16:08:26 Job still running ...
2023/02/20 16:08:56 Job still running ...
2023/02/20 16:09:26 Job still running ...
2023/02/20 16:09:56 Job still running ...
2023/02/20 16:10:26 Job still running ...
2023/02/20 16:10:56 Job still running ...
2023/02/20 16:11:26 Job still running ...
2023/02/20 16:11:57 Job still running ...
2023/02/20 16:12:27 Job still running ...
2023/02/20 16:12:57 Job still running ...
2023/02/20 16:13:27 Job still running ...
2023/02/20 16:13:57 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-20_08_04_55-11675659217827092535 failed
--- FAIL: TestXLang_Partition (581.02s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3260.848s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676906412355177573
--- FAIL: TestBigQueryIO_BasicWriteRead (5.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41347 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@tOUkXuKsuD"  is_bounded:BOUNDED  windowing_strategy_id:"w0@tOUkXuKsuD"}}  windowing_strategies:{key:"w0@tOUkXuKsuD"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@tOUkXuKsuD"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@tOUkXuKsuD"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@tOUkXuKsuD"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676906412355177573\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"tOUkXuKsuD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41347 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@tOUkXuKsuD"  is_bounded:BOUNDED  windowing_strategy_id:"w0@tOUkXuKsuD"}}  windowing_strategies:{key:"w0@tOUkXuKsuD"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@tOUkXuKsuD"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@tOUkXuKsuD"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@tOUkXuKsuD"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676906412355177573\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"tOUkXuKsuD"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 37 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000456a40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000456a40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000706780?, 0xc0000ba050?}, {0x1136f49, 0x39}, {0xc00015a0c0?, 0xa9bee0?, 0x1?}, {0xc000131cf0, 0xf}, 0xc0004f7d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000706720?, 0xc0000ba050?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc0004f7ea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131cf0, 0xf}, {0xc00004c4e0, 0x52}, {0xeb9520, 0xc0003f41a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00048eb60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00048eb60, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.406s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.029s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.042s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3dbd8c067ffe314878c14026aeeff47728cc7327a2734b805a8ab0070713239c
  Associated tags:
 - 20230220-151922
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-151922
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-151922].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3dbd8c067ffe314878c14026aeeff47728cc7327a2734b805a8ab0070713239c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220150732]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bb4e9ce2357f878751e2b83e81c2806333e1e8d4f77c0e86abc94f88de65970e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220150732] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bb4e9ce2357f878751e2b83e81c2806333e1e8d4f77c0e86abc94f88de65970e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bb4e9ce2357f878751e2b83e81c2806333e1e8d4f77c0e86abc94f88de65970e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bb4e9ce2357f878751e2b83e81c2806333e1e8d4f77c0e86abc94f88de65970e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220150732]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cba6deada8124892f9d8ec467cbf8b51df51d70e71c239674279effa4a295f67]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220150732] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cba6deada8124892f9d8ec467cbf8b51df51d70e71c239674279effa4a295f67])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cba6deada8124892f9d8ec467cbf8b51df51d70e71c239674279effa4a295f67
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:cba6deada8124892f9d8ec467cbf8b51df51d70e71c239674279effa4a295f67].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 27s
216 actionable tasks: 152 executed, 52 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1312

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1312/display/redirect?page=changes>

Changes:

[noreply] Bump github.com/tetratelabs/wazero from 1.0.0-pre.7 to 1.0.0-pre.9 in


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220082049",
            "environmentId": "iOSmsiHZBfbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202"
      }
    ]
  },
  "name": "go-testxlang_partition-459",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/20 09:15:51 Submitted job: 2023-02-20_01_15_51-9665023872174563855
2023/02/20 09:15:51 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-20_01_15_51-9665023872174563855?project=apache-beam-testing
2023/02/20 09:15:51 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-20_01_15_51-9665023872174563855
2023/02/20 09:15:51 Job state: JOB_STATE_PENDING ...
2023/02/20 09:16:21 Job still running ...
2023/02/20 09:16:51 Job still running ...
2023/02/20 09:17:21 Job still running ...
2023/02/20 09:17:52 Job still running ...
2023/02/20 09:18:22 Job still running ...
2023/02/20 09:18:52 Job still running ...
2023/02/20 09:19:22 Job still running ...
2023/02/20 09:19:52 Job still running ...
2023/02/20 09:20:22 Job still running ...
2023/02/20 09:20:52 Job still running ...
2023/02/20 09:21:22 Job still running ...
2023/02/20 09:21:52 Job still running ...
2023/02/20 09:22:22 Job still running ...
2023/02/20 09:22:52 Job still running ...
2023/02/20 09:23:22 Job still running ...
2023/02/20 09:23:52 Job still running ...
2023/02/20 09:24:22 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-20_01_15_51-9665023872174563855 failed
--- FAIL: TestXLang_Partition (549.87s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3139.962s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676881956031826058
--- FAIL: TestBigQueryIO_BasicWriteRead (4.27s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35025 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@eCAsFNceVB"  is_bounded:BOUNDED  windowing_strategy_id:"w0@eCAsFNceVB"}}  windowing_strategies:{key:"w0@eCAsFNceVB"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@eCAsFNceVB"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@eCAsFNceVB"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@eCAsFNceVB"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676881956031826058\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"eCAsFNceVB"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35025 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@eCAsFNceVB"  is_bounded:BOUNDED  windowing_strategy_id:"w0@eCAsFNceVB"}}  windowing_strategies:{key:"w0@eCAsFNceVB"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@eCAsFNceVB"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@eCAsFNceVB"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@eCAsFNceVB"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676881956031826058\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"eCAsFNceVB"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 37 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0000335c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0000335c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000508580?, 0xc000290000?}, {0x1136f49, 0x39}, {0xc00029e0c0?, 0xa9bee0?, 0x1?}, {0xc000130d40, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000508520?, 0xc000290000?}, {0xc0005b43c0, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000130d40, 0xf}, {0xc0005b43c0, 0x52}, {0xeb9520, 0xc00050a1a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005291e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005291e0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.307s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.040s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9120977d7a97d381bba9e2bc84d1f6803d36550cc7ee34d40cf6c9769598252d
Deleted: sha256:90d058752fd58102fbdee7c4f1f9d97c78b70c7de0974f11f37b7d90c21f3f04
Deleted: sha256:7b0c77074ece2ca395a8ee4780060df715e83676500c32720632d1916d4420f5
Deleted: sha256:7275d8d0503b3d87737f8451e2b96ab30b0e66b2bb2b07acffb847ce25c899ab
Deleted: sha256:b327111886409ca07b4da7582233d76553dcd5792413ce407af5f6d14356765f
Deleted: sha256:7ff6e3bdde4623174ba786894d6297dece0c32b1c18b63719f13647c1c200edc
Deleted: sha256:e568169ed8086a02d17a4d2455ae49888c9c988cef2f8944e9ea1b3499bd0beb
Deleted: sha256:c7a8cd3dafdbf74289f4e938ea6977f36dad8f8ecfc8715fdfe556d71f5d208f
Deleted: sha256:66d7aaacf03a2ed094fe3cb4d06e9d776c6fc874f91f2dea601d2344c2c7af48
Deleted: sha256:fd11eb92b3464b4ebba47592ecea7d0fb276571f65866d5464c8cbb2a3d4ae57
Deleted: sha256:4a99481782d868a2fdc655e8a018c11dce79829aed5c89a5a3a9e9d968d1e3c6
Deleted: sha256:c3f80833e25fd43b5ae5a5dd3fac8e7a233aa44388657d0583a0af90c59156d8
Deleted: sha256:88cea3bba55f43234bc83f78e2baae637d0fd6fa8852a355db05707ad5d3f721
Deleted: sha256:08d67290cd06e4cb886200b0b7fe60e1191f84aa6d2a06064cb957a19fc59af4
Deleted: sha256:60c7c6615fe69cf6e057466790d130c215b282eb9c531c49f59f50c42df4ce10
Deleted: sha256:580fe79dce3e01379750117f1a37d1f244f0dcc3c034c6d203675ab8482b3b5a
Deleted: sha256:3b91b51d05cc2c9a07164161872ef7452c2b556bb17b20cfb617c5546fe46a96
Deleted: sha256:208b10bc9a26c00878e4582e0a417d14b83a518727aefe447e40d2f8e704b397
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9120977d7a97d381bba9e2bc84d1f6803d36550cc7ee34d40cf6c9769598252d
  Associated tags:
 - 20230220-083202
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-083202].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:9120977d7a97d381bba9e2bc84d1f6803d36550cc7ee34d40cf6c9769598252d].
$ rm -rf /tmp/tmp.SKhmLvgUu8
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220082049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220082049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220082049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a733a655805840375db2952cbd68a84291848959088f7c659de44aafd95b920e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220082049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220082049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220082049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:984d73b54b796a5033ac423bb7e5bcdb35a808dc17f5007dae644fb3aa08a984].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3598291.
Stopping expansion service pid: 3598292.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 30s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1311

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1311/display/redirect?page=changes>

Changes:

[noreply] [Go SDK]: Retrieve file size in CreateInitialRestriction in textio.Read

[noreply] [#24789][prism] internal/worker + tentative data (#25478)

[noreply] [#24789][prism] add preprocessor and test (#25520)


------------------------------------------
[...truncated 1000.79 KB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-023145",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220022044",
            "environmentId": "pPhNGTotlDbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-023145"
      }
    ]
  },
  "name": "go-testxlang_partition-851",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/20 03:16:05 Submitted job: 2023-02-19_19_16_04-13249619575535329062
2023/02/20 03:16:05 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-19_19_16_04-13249619575535329062?project=apache-beam-testing
2023/02/20 03:16:05 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-19_19_16_04-13249619575535329062
2023/02/20 03:16:05 Job state: JOB_STATE_PENDING ...
2023/02/20 03:16:35 Job still running ...
2023/02/20 03:17:05 Job still running ...
2023/02/20 03:17:35 Job still running ...
2023/02/20 03:18:05 Job still running ...
2023/02/20 03:18:35 Job still running ...
2023/02/20 03:19:05 Job still running ...
2023/02/20 03:19:35 Job still running ...
2023/02/20 03:20:05 Job still running ...
2023/02/20 03:20:35 Job still running ...
2023/02/20 03:21:05 Job still running ...
2023/02/20 03:21:35 Job still running ...
2023/02/20 03:22:05 Job still running ...
2023/02/20 03:22:35 Job still running ...
2023/02/20 03:23:05 Job still running ...
2023/02/20 03:23:35 Job still running ...
2023/02/20 03:24:05 Job still running ...
2023/02/20 03:24:35 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-19_19_16_04-13249619575535329062 failed
--- FAIL: TestXLang_Partition (548.83s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3165.714s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676860343451714907
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45863 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gaKXNktKTG"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gaKXNktKTG"}}  windowing_strategies:{key:"w0@gaKXNktKTG"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gaKXNktKTG"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gaKXNktKTG"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gaKXNktKTG"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676860343451714907\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gaKXNktKTG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45863 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@gaKXNktKTG"  is_bounded:BOUNDED  windowing_strategy_id:"w0@gaKXNktKTG"}}  windowing_strategies:{key:"w0@gaKXNktKTG"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@gaKXNktKTG"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@gaKXNktKTG"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@gaKXNktKTG"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676860343451714907\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"gaKXNktKTG"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000127840})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000127840})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000698840?, 0xc00015c000?}, {0x1136f49, 0x39}, {0xc0006ae180?, 0xa9bee0?, 0x1?}, {0xc00048ac50, 0xf}, 0xc000669d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0006987e0?, 0xc00015c000?}, {0xc0006ac3c0, 0x52}, {0x1?}, {0xc000669ea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ac50, 0xf}, {0xc0006ac3c0, 0x52}, {0xeb9520, 0xc0003fa198})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.292s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:194becc73fd051d5526e10b814a0f5e92f6d04cec0d0e7edbcc6635e2706953c
  Associated tags:
 - 20230220-023145
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-023145
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230220-023145].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:194becc73fd051d5526e10b814a0f5e92f6d04cec0d0e7edbcc6635e2706953c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220022044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2fd49b57dedcc9385d445983389480a28e5dec22debb6cfde030df68058db11c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230220022044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2fd49b57dedcc9385d445983389480a28e5dec22debb6cfde030df68058db11c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2fd49b57dedcc9385d445983389480a28e5dec22debb6cfde030df68058db11c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:2fd49b57dedcc9385d445983389480a28e5dec22debb6cfde030df68058db11c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220022044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5d8945372d3e2488a60f0a50c7c3c14510b111ec939c9e6f0101abb011663260]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230220022044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5d8945372d3e2488a60f0a50c7c3c14510b111ec939c9e6f0101abb011663260])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5d8945372d3e2488a60f0a50c7c3c14510b111ec939c9e6f0101abb011663260
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:5d8945372d3e2488a60f0a50c7c3c14510b111ec939c9e6f0101abb011663260].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 47s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1310

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1310/display/redirect?page=changes>

Changes:

[noreply] Fix Tensorflow intergration test model path (#25553)


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219202044",
            "environmentId": "oFwOcTwqTFbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150"
      }
    ]
  },
  "name": "go-testxlang_partition-366",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/19 21:16:34 Submitted job: 2023-02-19_13_16_34-8275586645560278508
2023/02/19 21:16:34 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-19_13_16_34-8275586645560278508?project=apache-beam-testing
2023/02/19 21:16:34 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-19_13_16_34-8275586645560278508
2023/02/19 21:16:35 Job state: JOB_STATE_PENDING ...
2023/02/19 21:17:05 Job still running ...
2023/02/19 21:17:35 Job still running ...
2023/02/19 21:18:05 Job still running ...
2023/02/19 21:18:35 Job still running ...
2023/02/19 21:19:05 Job still running ...
2023/02/19 21:19:35 Job still running ...
2023/02/19 21:20:05 Job still running ...
2023/02/19 21:20:35 Job still running ...
2023/02/19 21:21:05 Job still running ...
2023/02/19 21:21:35 Job still running ...
2023/02/19 21:22:05 Job still running ...
2023/02/19 21:22:35 Job still running ...
2023/02/19 21:23:05 Job still running ...
2023/02/19 21:23:35 Job still running ...
2023/02/19 21:24:05 Job still running ...
2023/02/19 21:24:35 Job still running ...
2023/02/19 21:25:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-19_13_16_34-8275586645560278508 failed
--- FAIL: TestXLang_Partition (549.41s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3195.765s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676838743640646302
--- FAIL: TestBigQueryIO_BasicWriteRead (4.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34265 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@GAoXjYfGoi"  is_bounded:BOUNDED  windowing_strategy_id:"w0@GAoXjYfGoi"}}  windowing_strategies:{key:"w0@GAoXjYfGoi"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@GAoXjYfGoi"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@GAoXjYfGoi"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@GAoXjYfGoi"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676838743640646302\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"GAoXjYfGoi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34265 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@GAoXjYfGoi"  is_bounded:BOUNDED  windowing_strategy_id:"w0@GAoXjYfGoi"}}  windowing_strategies:{key:"w0@GAoXjYfGoi"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@GAoXjYfGoi"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@GAoXjYfGoi"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@GAoXjYfGoi"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676838743640646302\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"GAoXjYfGoi"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 30 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0004c2880})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0004c2880})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480b60?, 0xc000513680?}, {0x1136f49, 0x39}, {0xc00015e0c0?, 0xa9bee0?, 0x1?}, {0xc000042ff0, 0xf}, 0xc00066bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480b00?, 0xc000513680?}, {0xc0006043c0, 0x52}, {0x1?}, {0xc00066bea8, 0x2, 0x7f4069969800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042ff0, 0xf}, {0xc0006043c0, 0x52}, {0xeb9520, 0xc0001369e0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000492d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000492d00, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.239s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b7267e0f595e1f5cea81ce0022d2a1766da2de2ad2624a169dd6ee8265b903ec
Deleted: sha256:96ac615afb54cebc645a70ac32a3cb61bc61834426e7edf8592e6df69a750a5f
Deleted: sha256:6130a02422463d86dee6834bb88af491baae3fa9ca3ee8f329bbabb5139cba08
Deleted: sha256:5bf91d6c1720bdf9d75ab0aed9754c4e0066347a33ee480ea86bccc6c8c11db0
Deleted: sha256:49f549f5061661a77228652ee0596fc4cb8dd58a671d468c494be83399128b81
Deleted: sha256:c4540f4373ea641a7209d08683f455f739ca23b2e23cef721bbef7f22ba35411
Deleted: sha256:ca25bff501ba3d2c59925d63736a8de5a7a3711cf644bef67b0cae9d027599f0
Deleted: sha256:f051cb0aae7c9e1a3c96e61e3e010a958181594c97decf84075c4f197dc623e2
Deleted: sha256:2118d3946768a6fec872c50ebe96f4015412903841edfa2e93cf826e165e6ec8
Deleted: sha256:65de42e1406fed4b2a1e442bce17e4aea514da71649925d8e2c20867d86dc7f9
Deleted: sha256:708fdc7ea473fd98e09b419063fd79305b158b3e7a6fb89af4307d11b49fbc9c
Deleted: sha256:0dadb1a883a891073e816fc3041b7fa02217986d5aed6e2b412148f341b72144
Deleted: sha256:679c2f6ae17679b50d23df9c0cb0d7f90801fec97cb8a5ab03d01992548b849f
Deleted: sha256:c0e8d9994983185489e8cd6aba358882f15431c9baa57c588e6e5ad798b053b1
Deleted: sha256:5febc6d49728d07e87df528dde92233c896f89a6b09643df9a12efdce83e776f
Deleted: sha256:8854e910e7e505ff78df3ff9169f8f70031b9390646a9b5a77b4ca729e47ad4b
Deleted: sha256:b295b859c318d97bc9b0a0bf308b784704bddd8a286073512705465ba11365fc
Deleted: sha256:cb0913d5f2260d9ca896037d3f54dc1619c870df4b08859d8f0e1c4b56a015db
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b7267e0f595e1f5cea81ce0022d2a1766da2de2ad2624a169dd6ee8265b903ec
  Associated tags:
 - 20230219-203150
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-203150].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b7267e0f595e1f5cea81ce0022d2a1766da2de2ad2624a169dd6ee8265b903ec].
$ rm -rf /tmp/tmp.Q7KVMJ5wVg
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219202044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e95142914adf5acaa37a6287be75201aec2eaa87072ba9e83bf145aa65afc75b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219202044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:95b3e18c08ff0aaa311cbdc63a70139d07e3955d26fcefa78080b2179c2fbe65].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2817967.
Stopping expansion service pid: 2817968.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 16s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1309

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1309/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
2023/02/19 15:22:08 Job still running ...
2023/02/19 15:22:38 Job still running ...
2023/02/19 15:23:09 Job still running ...
2023/02/19 15:23:39 Job still running ...
2023/02/19 15:24:09 Job still running ...
2023/02/19 15:24:39 Job still running ...
2023/02/19 15:25:09 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-19_07_16_38-16879228256351142383 failed
--- FAIL: TestXLang_Partition (549.02s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3197.225s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676817145215939033
--- FAIL: TestBigQueryIO_BasicWriteRead (4.29s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wShoqvZTJz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wShoqvZTJz"}}  windowing_strategies:{key:"w0@wShoqvZTJz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wShoqvZTJz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wShoqvZTJz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wShoqvZTJz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676817145215939033\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wShoqvZTJz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34793 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wShoqvZTJz"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wShoqvZTJz"}}  windowing_strategies:{key:"w0@wShoqvZTJz"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wShoqvZTJz"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wShoqvZTJz"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wShoqvZTJz"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676817145215939033\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wShoqvZTJz"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 41 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000113740})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000113740})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004808e0?, 0xc00054e000?}, {0x1136f49, 0x39}, {0xc00015e180?, 0xa9bee0?, 0x1?}, {0xc0003f6d20, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480880?, 0xc00054e000?}, {0xc0004ca420, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7f0e0ed6c410?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d20, 0xf}, {0xc0004ca420, 0x52}, {0xeb9520, 0xc0004a2200})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000493520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000493520, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.327s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-143151
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-143151
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a855798e442d5558f63307aa34af59919b5427d1b0be66784dcfea173ed92217
Deleted: sha256:8855285d2423f9b4cc4cf5272d92fb964d65d710b4e209ad1fa61994be1f8d24
Deleted: sha256:bd7519bed629fb825127f599517fa1eededf748ab65bbe502cd722215d4de1ca
Deleted: sha256:7216116b8452f42ba377ec4adb0d6e5e101c231de21ca7ff4c7b6ec65026ba4c
Deleted: sha256:a2d6f989c3899621c7715e651637305b38aeaf43277cbbc119b3b165ae20d1d4
Deleted: sha256:d502c73d01cd476fc1caef35acb68a4f3c428973abc609713428614d964616e0
Deleted: sha256:639b50ec0d6776757b92b49bac1c9f0c8950c1b0aeb5287599a34efa9300edf0
Deleted: sha256:38d27dbf0db5bf4b61f739b89a344ed0d84cbd62e43f004703307b6042ebf53b
Deleted: sha256:7871fbedf054bed24c6de2c81dbbb3b7beddef30810e952a02d114a5e2a1b8c5
Deleted: sha256:ffd67d878edd0974c1803e0c59fc074fc7ef74d68df9bb8fd3fc015309feeb1b
Deleted: sha256:676420bef68b5966caf915892c5ea8f24e86cc4eb9eb618696cd243595b28664
Deleted: sha256:646c0b03cb6fa051d78fc781576a3e93dcc6a587e0222bae5c2bedc3615cc852
Deleted: sha256:6f2f0549ae8e3c9e313f312d7e8480fe9f04fc2217faa92fdbd92991ee34f28f
Deleted: sha256:dd8d1c90c974c561e6e3b21d2a152d893059aa4a559450832fd2a64ec4bea8fb
Deleted: sha256:0904a817507c87678a7c79bab83d78277e2b8e98d04914708c4a916e8efa0adf
Deleted: sha256:e5ca8a55553cd83a0db184302b3cb75a0d6116c705afadce1b3cbd507d0c1ce8
Deleted: sha256:e14d78b6de6f636527e051775a103f3c0402fc81c917c6be781f1e81d8beccb4
Deleted: sha256:20a7dcc04b3a9e622a18ea4a3275b068eaadb7e00569d17d272e043053707d17
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-143151
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a855798e442d5558f63307aa34af59919b5427d1b0be66784dcfea173ed92217
  Associated tags:
 - 20230219-143151
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-143151
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-143151].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a855798e442d5558f63307aa34af59919b5427d1b0be66784dcfea173ed92217].
$ rm -rf /tmp/tmp.NMuVsz7NWo
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:62864cd15bc383c4951b0509085482751a58a3159f13f68779d099af2e989fa8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536
Deleted: sha256:1cb45f8216f65fb1898054309f6239d6b3c04a2becc4e0e835d7fa952393fee9
Deleted: sha256:c5e244aa839b77252828b0aad2af567ce78c774735b72f6ecf844f479ab0851f
Deleted: sha256:6c3f9f98e66532e8f0d6a7f24cea13da89ed5b993c91c4ed69dc92b12442438c
Deleted: sha256:dd4a37f49e533017f22740992ceffb76cf6fb763f391dc5cf985235e3da35fd1
Deleted: sha256:c2b0edcfd24963c4d13b2f46ba4de95622564569f82595977ef823fbb5c5d500
Deleted: sha256:785fd5bf8a9a2de848f1c5fd7b705b9321d0a1faacd29eb48999141fec59396a
Deleted: sha256:bbacb94c4fce6ddfc05e781586d43fade367673bf55f8cbe1369deed98ce5ab0
Deleted: sha256:a31fbafbe2276578523b5f70f61aa88c4ce1b578dda41eafe58c86c42762706c
Deleted: sha256:db8d12333933170f80e9db27bcc8b0bd13ae2c3421d17e4be06392bac9908be8
Deleted: sha256:9fa55419650c08cd59375491bbdcbab7cb2264f4f20cd046fd59d949d8f09f30
Deleted: sha256:b841a73d44d966d9db61a9e3ec4286a102b22f2425fa6a8df7db26698df313c6
Deleted: sha256:458e661d4dfebb05039a9be10abcba98c22737229f9036a546ff2af4fa6da944
Deleted: sha256:66908169d2ba1c7a4ab88fdf9e3019cb4b7c3bab319e3fd10bc9332a12cd0168
Deleted: sha256:839db11736c19f23e673566fcb94fda62b94abaa6c94bdc7f929e71e8cc34f6d
Deleted: sha256:074ffb33919d39de3a6923f8c1a78d4ff665aaf30674e2a99ec0c3762bea1e9b
Deleted: sha256:041368970069464ab459f20505afa8499a9c069be92b658d2ac5fddfaf5d9ee3
Deleted: sha256:e2727ffd5f1abe29dd1d4509d663359443da69b609791e23ffa95efb5dd0566c
Deleted: sha256:b413d89d5173a7f5d56cc0d826c73b3e468816369a8849902b8f8d5f0efe845b
Deleted: sha256:14602acf123ef1ecdd9a966fdaf70d2648da1873d3cf76198f277de40f4d87e8
Deleted: sha256:a061c29a66c34c62a0e68f5becc2233d068cb45df8bcaebaf65ebefec6daca39
Deleted: sha256:8de29923441add442fd49c970aef121a6d27f491c238235079f44402dad1141f
Deleted: sha256:e52062d1123e158ccbb2b1f3203d80c4ba484a24386942f9953ba88d931b5129
Deleted: sha256:a0cc84ca24b08e2ae6bbd9fb415b1be64fbf9aa99047fe5a3610f2e88ad36cbf
Deleted: sha256:bd74a4ab9bf97c070da0abe396a95badd813d05c1cfd9ad347810e04b20175fb
Deleted: sha256:71dadfb22c5a61b3e7288882ba5df7458573c79e4eddab8e2d6e294d47903bdf
Deleted: sha256:2e3b90b5abd7d625ae24c4f1f1c00e1f6e118a405621435bcf60f58f13ce2a7c
Deleted: sha256:fabc38bcaf9289fb143aa17403723a7d5ddb93282e75fad92587e3df8ac2b551
Deleted: sha256:70a54f3d77297b3533755db380152c7fb08579a89a5ceb5b320017d43298a847
Deleted: sha256:58583713833847cacb97729611eb73647f28785796cbbd253a906be9c86de3e7
Deleted: sha256:744ca0945c048c41907b1f2396e31d5112e91413f236ab86296a82472dec2c04
Deleted: sha256:405cdebdc1d06e91dfae474c6b6e77cbe31c65c4d31f369926a9ddb2799b5b34
Deleted: sha256:bef40a2e6a3c87b89a8fd4e29c5e9c9aea6f2a05eddf1b829a37f5cdf375941b
Deleted: sha256:39ad7a6dbbcf4c5cd17f562426e620191562f6c52a0f701f922467e72cdf9f65
Deleted: sha256:1b08002f882abec041e1285aca25c1fe591195cca51447cfd065665bf400a748
Deleted: sha256:bc63ed9da9ed8bb62668670c330ecea15f9b1c4014d6f04b8e308498df1d9d96
Deleted: sha256:a9ebdfb2fc8bf8265d187fef4e2402ac8550130718cab86e375f104d741f7f74
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8b13fd8dc4d23ac35dc9bcca093c725f5cee25a1b2834ae2196f9a9f89ffa536].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2489327.
Stopping expansion service pid: 2489328.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 14s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1308

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1308/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219082048",
            "environmentId": "EOCfwrYLRobeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203"
      }
    ]
  },
  "name": "go-testxlang_partition-336",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/19 09:16:25 Submitted job: 2023-02-19_01_16_25-17835873131731450712
2023/02/19 09:16:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-19_01_16_25-17835873131731450712?project=apache-beam-testing
2023/02/19 09:16:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-19_01_16_25-17835873131731450712
2023/02/19 09:16:25 Job state: JOB_STATE_PENDING ...
2023/02/19 09:16:55 Job still running ...
2023/02/19 09:17:25 Job still running ...
2023/02/19 09:17:56 Job still running ...
2023/02/19 09:18:26 Job still running ...
2023/02/19 09:18:56 Job still running ...
2023/02/19 09:19:26 Job still running ...
2023/02/19 09:19:56 Job still running ...
2023/02/19 09:20:26 Job still running ...
2023/02/19 09:20:56 Job still running ...
2023/02/19 09:21:26 Job still running ...
2023/02/19 09:21:56 Job still running ...
2023/02/19 09:22:26 Job still running ...
2023/02/19 09:22:56 Job still running ...
2023/02/19 09:23:26 Job still running ...
2023/02/19 09:23:56 Job still running ...
2023/02/19 09:24:26 Job still running ...
2023/02/19 09:24:56 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-19_01_16_25-17835873131731450712 failed
--- FAIL: TestXLang_Partition (549.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3169.653s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676795560183835604
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34323 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lIpRwtsfxr"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lIpRwtsfxr"}}  windowing_strategies:{key:"w0@lIpRwtsfxr"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lIpRwtsfxr"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lIpRwtsfxr"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lIpRwtsfxr"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676795560183835604\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lIpRwtsfxr"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34323 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@lIpRwtsfxr"  is_bounded:BOUNDED  windowing_strategy_id:"w0@lIpRwtsfxr"}}  windowing_strategies:{key:"w0@lIpRwtsfxr"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@lIpRwtsfxr"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@lIpRwtsfxr"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@lIpRwtsfxr"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676795560183835604\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"lIpRwtsfxr"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000206c40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000206c40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7220?, 0xc0000cb860?}, {0x1136f49, 0x39}, {0xc00015c0c0?, 0xa9bee0?, 0x1?}, {0xc000043270, 0xf}, 0xc000031d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a71c0?, 0xc0000cb860?}, {0xc00004c660, 0x52}, {0x1?}, {0xc000031ea8, 0x2, 0x7f8f8614d888?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043270, 0xf}, {0xc00004c660, 0x52}, {0xeb9520, 0xc000134ea0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00054d860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00054d860, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.427s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:42a22956711667944b1e247b7f04e662392d7ae4ae3b7626c21c8b9fa0eb87da
Deleted: sha256:828ca347208ab1fec359782616c17985a06b0010cbab54b443bf48073b0e941c
Deleted: sha256:7cb3119e6b48a60a7e3a883b9a7b9fa628f540e806bdaf5007c0bcda9dbbc44b
Deleted: sha256:76597e2e4894c9f03c0a1e6ad486c807d5449ef8c3107b5a7f08a32695bb49bf
Deleted: sha256:d7c5a73e4c5e0c25dad391367469bf5b2af6325900cfc98c801e8ea7446a7c44
Deleted: sha256:f8175cd2e43d03ea176ddc726cee44ea69b06a86621ff5418ebf3725bcb6ca12
Deleted: sha256:65e0b359a03df99de630b051ed5e377a91eac75a84f364053939d14f3e4c5713
Deleted: sha256:2d00eaddf919e314da4a8301fca0a0586574814b8c2508ce735982d86b1ec8da
Deleted: sha256:7f9dd212368ccd938c621df9f675c9486500b7b9747062b6b5ddb3bdfec4b55e
Deleted: sha256:5fab5b8b69e4ce67f1a38243ccdbc8893bcbb3397570a8d7a8897db98e68f2ea
Deleted: sha256:3b3db141c85add76612318a1a60b61327d08c2cc17dc8ba029cc49f2a1d423b2
Deleted: sha256:3f05c7d47ef1e4aca2e8cece84803f7de3cab11201f44aa37b6629ad1f058b52
Deleted: sha256:d307982949fdfff7617208cbd8a72814086480b78e9c78a26949d29a462e9610
Deleted: sha256:bb54cbeeda8060ee98024c34719e93142d05c8baf7b50066154987dd2a6fa3ad
Deleted: sha256:294c5b5fe7f813e8283541df687a998a58f717666aa4f2cafebf5e12ff452e9e
Deleted: sha256:d00763be43f66080bd902716242197cec547f42d3be41b512910095757249cc5
Deleted: sha256:6cbaecd6cfca031b26810e4e5e0e9909efbd2d4f5bc03abb2324adc2a8d48303
Deleted: sha256:52fab72331f2d7875f91163fa4beccb066528c7a32f0f92fb393d636b554bdb2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:42a22956711667944b1e247b7f04e662392d7ae4ae3b7626c21c8b9fa0eb87da
  Associated tags:
 - 20230219-083203
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-083203].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:42a22956711667944b1e247b7f04e662392d7ae4ae3b7626c21c8b9fa0eb87da].
$ rm -rf /tmp/tmp.OvwUcwACqI
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219082048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:867e437b937ed1d9fbfec6fab3479f552a68bbca5a07add6879bae550d32517b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219082048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dcb71897f01fa38596065c10f12b564b1b1466b0af135ff03c3b8538db131048].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2293369.
Stopping expansion service pid: 2293370.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 4s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1307

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1307/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219022045",
            "environmentId": "tctCbFoAJibeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143"
      }
    ]
  },
  "name": "go-testxlang_partition-272",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/19 03:16:01 Submitted job: 2023-02-18_19_16_00-7538052620341843399
2023/02/19 03:16:01 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-18_19_16_00-7538052620341843399?project=apache-beam-testing
2023/02/19 03:16:01 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-18_19_16_00-7538052620341843399
2023/02/19 03:16:01 Job state: JOB_STATE_PENDING ...
2023/02/19 03:16:31 Job still running ...
2023/02/19 03:17:01 Job still running ...
2023/02/19 03:17:31 Job still running ...
2023/02/19 03:18:01 Job still running ...
2023/02/19 03:18:31 Job still running ...
2023/02/19 03:19:01 Job still running ...
2023/02/19 03:19:31 Job still running ...
2023/02/19 03:20:01 Job still running ...
2023/02/19 03:20:31 Job still running ...
2023/02/19 03:21:01 Job still running ...
2023/02/19 03:21:31 Job still running ...
2023/02/19 03:22:01 Job still running ...
2023/02/19 03:22:31 Job still running ...
2023/02/19 03:23:02 Job still running ...
2023/02/19 03:23:32 Job still running ...
2023/02/19 03:24:02 Job still running ...
2023/02/19 03:24:32 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-18_19_16_00-7538052620341843399 failed
--- FAIL: TestXLang_Partition (549.14s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3166.521s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676773938925461045
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34265 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@LZfAwaCPCC"  is_bounded:BOUNDED  windowing_strategy_id:"w0@LZfAwaCPCC"}}  windowing_strategies:{key:"w0@LZfAwaCPCC"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@LZfAwaCPCC"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@LZfAwaCPCC"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@LZfAwaCPCC"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676773938925461045\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"LZfAwaCPCC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34265 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@LZfAwaCPCC"  is_bounded:BOUNDED  windowing_strategy_id:"w0@LZfAwaCPCC"}}  windowing_strategies:{key:"w0@LZfAwaCPCC"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@LZfAwaCPCC"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@LZfAwaCPCC"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@LZfAwaCPCC"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676773938925461045\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"LZfAwaCPCC"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00058f880})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00058f880})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005901c0?, 0xc000130050?}, {0x1136f49, 0x39}, {0xc0005ae0c0?, 0xa9bee0?, 0x1?}, {0xc00065ce10, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000590160?, 0xc000130050?}, {0xc0004a4480, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f76cebe5c40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00065ce10, 0xf}, {0xc0004a4480, 0x52}, {0xeb9520, 0xc0001220a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000493040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000493040, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.476s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6b555cc5ee3861c0c83de8e50374b5d667a8d632ad615f4a77f20933bbd155f9
Deleted: sha256:de850227cd349033291e1cb441ea4b01348be305c01a9fdc058b756dab8180bb
Deleted: sha256:c7ea9223b68e3fe93cc7864645dfff934175570134537def1d652a2ac3ea1c8b
Deleted: sha256:b7d5f5397ef51816f6f5d987b27837b5f7c005659890951a84f7e2d6ef6c2ff5
Deleted: sha256:9009a20fda8e8af563e270fc75547eaa1a7f1d9f267be7ab5dcb2a9e8e9a4c97
Deleted: sha256:e284c78709415c5585cb4c028ce9212a3a1eaf5b809aee36b1f3031d07bdd8ff
Deleted: sha256:3467fa886c2ae25f294a226afdceb7b4e505995beac92b70f6b6a9182e4bf46f
Deleted: sha256:94be8316a288d1b5ab255b84847674edfe4797efea196eb5e145076001ab104f
Deleted: sha256:6b2c3c243a1f95d8a0e52224bb7c7204a36e23c27b266a501351d711f5e77e68
Deleted: sha256:693be173e9263eb6660f4ec64bc715a3b003b4ba2a45519ebe8b17d27dddb4cf
Deleted: sha256:a109e29b6960e1e928964fac8198a37c13e25e5bcba31614f6aa39ce5a55bbbf
Deleted: sha256:996b0f2ee317bc3ccc868c5284197e596ab7fa31355985668d9d2ebf2617ff5f
Deleted: sha256:85ffdd76582f252a2be4d4e050d01f00205f76dca699a2a731030cb6178c0494
Deleted: sha256:97c7c73cc73d9fdc4009187b29212fc69f5eca1b9cea1e24268484fda2d4a2e6
Deleted: sha256:92afc535e790201b43edf73d61f60afd2beb0e53c56249734c1212b987cf4cde
Deleted: sha256:910a21d7fc250914e1ac272feb218b477141737059e3e4397f7673797a801e4a
Deleted: sha256:c78267f3a57d1577561b29d049cc6b928c167db35005259f6e6d1b25d1532279
Deleted: sha256:1f24df8fc667ae9d7df35e79e3890bfb7089033ea84aef587f18285c10eb8683
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6b555cc5ee3861c0c83de8e50374b5d667a8d632ad615f4a77f20933bbd155f9
  Associated tags:
 - 20230219-023143
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230219-023143].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6b555cc5ee3861c0c83de8e50374b5d667a8d632ad615f4a77f20933bbd155f9].
$ rm -rf /tmp/tmp.M3AtsAQO62
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230219022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ec6e24c62b24187e8f8551349217667ce272c66cd84bde83fb9a8382257e9931].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230219022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8fc3600404da65d1911925954f1344f55608cd2f0fd0216b5daeb95198ca3871].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2116525.
Stopping expansion service pid: 2116526.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 42s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1306

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1306/display/redirect>

Changes:


------------------------------------------
[...truncated 533.74 KB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-203159",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218202048",
            "environmentId": "xMNnxODAYnbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-203159"
      }
    ]
  },
  "name": "go-testxlang_partition-385",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/18 21:15:49 Submitted job: 2023-02-18_13_15_48-4864736779899794349
2023/02/18 21:15:49 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-18_13_15_48-4864736779899794349?project=apache-beam-testing
2023/02/18 21:15:49 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-18_13_15_48-4864736779899794349
2023/02/18 21:15:49 Job state: JOB_STATE_PENDING ...
2023/02/18 21:16:19 Job still running ...
2023/02/18 21:16:49 Job still running ...
2023/02/18 21:17:19 Job still running ...
2023/02/18 21:17:49 Job still running ...
2023/02/18 21:18:19 Job still running ...
2023/02/18 21:18:49 Job still running ...
2023/02/18 21:19:19 Job still running ...
2023/02/18 21:19:49 Job still running ...
2023/02/18 21:20:19 Job still running ...
2023/02/18 21:20:49 Job still running ...
2023/02/18 21:21:19 Job still running ...
2023/02/18 21:21:49 Job still running ...
2023/02/18 21:22:19 Job still running ...
2023/02/18 21:22:49 Job still running ...
2023/02/18 21:23:20 Job still running ...
2023/02/18 21:23:50 Job still running ...
2023/02/18 21:24:20 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-18_13_15_48-4864736779899794349 failed
--- FAIL: TestXLang_Partition (549.49s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3135.472s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676752358197801468
--- FAIL: TestBigQueryIO_BasicWriteRead (4.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42817 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RmgqRAIiOA"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RmgqRAIiOA"}}  windowing_strategies:{key:"w0@RmgqRAIiOA"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RmgqRAIiOA"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RmgqRAIiOA"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RmgqRAIiOA"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676752358197801468\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RmgqRAIiOA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42817 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@RmgqRAIiOA"  is_bounded:BOUNDED  windowing_strategy_id:"w0@RmgqRAIiOA"}}  windowing_strategies:{key:"w0@RmgqRAIiOA"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@RmgqRAIiOA"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@RmgqRAIiOA"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@RmgqRAIiOA"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676752358197801468\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"RmgqRAIiOA"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0002f57c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0002f57c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fc0?, 0xc000111ae0?}, {0x1136f49, 0x39}, {0xc0002a2000?, 0xa9bee0?, 0x1?}, {0xc000133d70, 0xf}, 0xc000207d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f60?, 0xc000111ae0?}, {0xc00055e360, 0x52}, {0x1?}, {0xc000207ea8, 0x2, 0x7f97d56afc10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000133d70, 0xf}, {0xc00055e360, 0x52}, {0xeb9520, 0xc00017f090})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00035f1e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00035f1e0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.483s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a0dbf147ae1f5f087493450179621aa58dd5c56d85f3208c1c5351dfbc61a2cc
  Associated tags:
 - 20230218-203159
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-203159
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-203159].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a0dbf147ae1f5f087493450179621aa58dd5c56d85f3208c1c5351dfbc61a2cc].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5469448f3befbad497fcff37542f5fc57609d20f08b2f8df6aa8f891977e3f7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5469448f3befbad497fcff37542f5fc57609d20f08b2f8df6aa8f891977e3f7])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5469448f3befbad497fcff37542f5fc57609d20f08b2f8df6aa8f891977e3f7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b5469448f3befbad497fcff37542f5fc57609d20f08b2f8df6aa8f891977e3f7].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:31d5163ff789ef780ddd5072ca6aa0f43e6d8065517f7fb384a636c7eebf67a9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:31d5163ff789ef780ddd5072ca6aa0f43e6d8065517f7fb384a636c7eebf67a9])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:31d5163ff789ef780ddd5072ca6aa0f43e6d8065517f7fb384a636c7eebf67a9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:31d5163ff789ef780ddd5072ca6aa0f43e6d8065517f7fb384a636c7eebf67a9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 28s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1305

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1305/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
2023/02/18 15:21:05 Job still running ...
2023/02/18 15:21:35 Job still running ...
2023/02/18 15:22:05 Job still running ...
2023/02/18 15:22:35 Job still running ...
2023/02/18 15:23:05 Job still running ...
2023/02/18 15:23:35 Job still running ...
2023/02/18 15:24:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-18_07_15_34-9068131648356597464 failed
--- FAIL: TestXLang_Partition (549.74s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3138.603s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676730740303775327
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35551 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@okpGMWRFbt"  is_bounded:BOUNDED  windowing_strategy_id:"w0@okpGMWRFbt"}}  windowing_strategies:{key:"w0@okpGMWRFbt"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@okpGMWRFbt"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@okpGMWRFbt"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@okpGMWRFbt"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676730740303775327\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"okpGMWRFbt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35551 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@okpGMWRFbt"  is_bounded:BOUNDED  windowing_strategy_id:"w0@okpGMWRFbt"}}  windowing_strategies:{key:"w0@okpGMWRFbt"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@okpGMWRFbt"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@okpGMWRFbt"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@okpGMWRFbt"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676730740303775327\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"okpGMWRFbt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 56 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000560640})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000560640})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000586c40?, 0xc0001316d0?}, {0x1136f49, 0x39}, {0xc0000f00c0?, 0xa9bee0?, 0x1?}, {0xc000043da0, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000586be0?, 0xc0001316d0?}, {0xc000598360, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f3194053ac0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043da0, 0xf}, {0xc000598360, 0x52}, {0xeb9520, 0xc0005f70c0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.297s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-143146
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-143146
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c5dc9b758bbb63f65d1f031f1691909ae711635582b1ec0bc1588e9398186bcb
Deleted: sha256:145a1effc95e841c1d96f94f07d0391ef7d71ff156f99ffe266947c5c511a21e
Deleted: sha256:b6570a3b8fe13a2a3fa779da4959e8f92925d9f0e20dc9783025025812001c9e
Deleted: sha256:a4ad160c666d1fb53fc56cf3a19b116ce6d203972da1dc4d57be51c76c14b1c3
Deleted: sha256:4680c61654fb807b0fc50e38080dc0de1a19e9c1f829c29651135aa9261bd67e
Deleted: sha256:d40bff61ba4bb01efa17cdddc1c61f60d6e022453564444c8b9f29b93947c024
Deleted: sha256:0e67be0338e0236a9ce1f8001144c2fbc7a6294733fed9acda3a0b3f6973f1fe
Deleted: sha256:ddbaa738f8e984d0cbb171a89e72d33721be5ed3c49231ad52fc49dd97b28e51
Deleted: sha256:9864650275758f7b87184bdd4f24293c55e69591e171d8f6a679714bfabfc1ed
Deleted: sha256:4608efdf3313f9499ffcbd696ea68d6f6d779999f3543f433d71579d862b4aa8
Deleted: sha256:9638bfba4522b63eac81e542d2a7a585f47fea982759688d83b41ad6bad878ff
Deleted: sha256:7197439a8ccf77d33087d780071953a70e1746758006093773a92d2d581c6a11
Deleted: sha256:aa0535867468025e3390a18be50a171e6e77bc300da6324795f88e95dbfecf27
Deleted: sha256:772031ae1305773dfb58527086e77109ff5b30324f281f76ca61387a572ce4eb
Deleted: sha256:5b58f5e353c69f9b33b7d22fc4122acbf48d61cc599357252cb4428f118b036e
Deleted: sha256:53a0f8d25f054154e1f14c462885aaa83370f455b06065653bea055f1ab6ca5a
Deleted: sha256:15b03bca29295d80c4978a292cff3f9f2eb6074d92bb1435e07726d26efac378
Deleted: sha256:c0525d06bc172b0aae2e30e9bbf1fae4691e842d3610adbb00baa0d06fbc4734
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-143146
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c5dc9b758bbb63f65d1f031f1691909ae711635582b1ec0bc1588e9398186bcb
  Associated tags:
 - 20230218-143146
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-143146
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-143146].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c5dc9b758bbb63f65d1f031f1691909ae711635582b1ec0bc1588e9398186bcb].
$ rm -rf /tmp/tmp.BqvdEuJxjW
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:43a2e60838dd9b0b63fd26b62b2072e0b76f2f7e4fee74ee2dc3b0ec32a60f66].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244
Deleted: sha256:02c691edad6a996d00b6017225120cffc64c2442e1609425c973b73ca961d31f
Deleted: sha256:2832d2361901eb02ba76523ea794e5da9ff390e2ce8e6444787f4c17c43a436c
Deleted: sha256:a90612132ed5fef0fcfaf66e6a61109c752893422288b6184e08c1c1040e1d6b
Deleted: sha256:9832df97765dd179cbf027fdd36f094c3882ffe2dbcbc145161271fe0f20e6c9
Deleted: sha256:d5d930d801d5f49aa9bda5e06bfb3a66b5aae6910ee9606a6e1bc5d954186df3
Deleted: sha256:5438c581a93ee7ebf2afc98156848e8607c6ec7833f00a6d94c855f1a5763b18
Deleted: sha256:8b0ab2e146765786a47047d4bbb1470e97d477ab54a8f44d431b44422a63095f
Deleted: sha256:a1b4a508c335129116fdd8e01ad1b5cdbdf98a5c079eaab9820a7a1f1b1caa90
Deleted: sha256:aa8e921570fec2fd58ce3c976c81ca0c602ba64d2f79c4a928a3918690bd96ad
Deleted: sha256:7342d55ef678f4e520c4aa47b350c156015771a690686abb59079c77a6be4c52
Deleted: sha256:2d40211e948c3f46f574c8f694a325a1644491d2cc51fc293484c583e51efa20
Deleted: sha256:51b4432c81383b31b6c3d1b0bee765454358cf5f1915f686255fdaf8c19f5134
Deleted: sha256:2b999e3381756cc9c8b9e7fc0d8572c668e05e3993ede1946363e3ec2e360d40
Deleted: sha256:4042755eebd108d7c41fc1ae583a84090a6ef1befb1292c1e1ca3201679cf34b
Deleted: sha256:3e89e42ba054217d4a0440ccaf3c24dccd5e6eded495414e1b37920efac3b9ba
Deleted: sha256:f7fbe24cb4a2497abcbc5eeddb1635f1f4247b6e92f974ef97e756bb85329b3b
Deleted: sha256:4e65471073f75b3d74da329e7b0ed833cf19db6ab0d0248a6a96cd71ff02aa9e
Deleted: sha256:cf8ce3b5b73a9bab9c8c96e0f4a1986598c8af1ff022d48566b4a853ab2aa574
Deleted: sha256:ac8a6c13bdae28127ddd90c8597375ef86da7ec3682ddc85be3dee4c99041020
Deleted: sha256:2d95c888d44580cfc7bcd5b3244ac9bbae44f1b9cfec9ccb8471341eb1350508
Deleted: sha256:579ba1176f37e78e1f43d58f0f3e43e31c6d9cc8c1a9f80c570280f6890d9653
Deleted: sha256:74b0dd39f78b024191dc6c4d3d0081496a88f18889f5b777dc575582774455f4
Deleted: sha256:1a94753a83c50bbc51057214526f87c96ff14896d0f1fc04044fd2251b47be21
Deleted: sha256:334ec092126d5176e3a35f10cfb7d5c7441f978ad096c50c8779b17ef756777a
Deleted: sha256:013f83150410f2142a23b3d7cd0a758e3d2c9137b3bf45ea8250635876c14b2a
Deleted: sha256:0e0da7a336fbb401f672952107dcfc18de980de8831ed62e4683ad21bbab0b5d
Deleted: sha256:a61e6b422be56112f1832b15d10cf0d9ac6560500569ef86aada14aa1740d53d
Deleted: sha256:8c66288aefa3054b68dbbb98d840cd86135088c493229f88df4a781b521ce91c
Deleted: sha256:156490cb90f75a61b9ee18b4d4f90ede3977f722107d4d45bb1152b077c2f4af
Deleted: sha256:a7a35d20d221fd524f11d615289b45d8c69db5edba538e10eef4661d05b874d3
Deleted: sha256:c091b8aa59a7b01782e4d32b0a93c9d4c7e9469039064cc955ffc962e894cf95
Deleted: sha256:85500497e784f1a34be53be064b9c3d834f89e1a146d9744db895fe80c924563
Deleted: sha256:4dfe734a3e372b289f3d8cc6105db90b472b2ab237ffdaea167b52ee183bb807
Deleted: sha256:ca575b43c38c6b13ace9e662389831c145695ddb5662fdc9fadaad5ed1b9bbce
Deleted: sha256:3aeefabc2b777bd30829f1c383e457ec79186f088aefe1dbefca6bd97d5f08a1
Deleted: sha256:bfd46ac4c55f6796108a712178e4e8e6d5c8b90e475f0a650cd92f82e51720ce
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2dd0cbea67cbab610ac45518d342e7359dde82cf6935fdc8a6b12cff77867244].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1600749.
Stopping expansion service pid: 1600750.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 14s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/64dqfzlzjhugq

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1304

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1304/display/redirect?page=changes>

Changes:

[noreply] [prism] add windowing strategy (#25518)


------------------------------------------
[...truncated 991.77 KB...]
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218082044",
            "environmentId": "euHXTZSNPVbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.46.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-083140",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-083140"
      }
    ]
  },
  "name": "go-testxlang_partition-310",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/18 09:15:58 Submitted job: 2023-02-18_01_15_58-1172981506071348071
2023/02/18 09:15:58 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-18_01_15_58-1172981506071348071?project=apache-beam-testing
2023/02/18 09:15:58 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-18_01_15_58-1172981506071348071
2023/02/18 09:15:58 Job state: JOB_STATE_PENDING ...
2023/02/18 09:16:28 Job still running ...
2023/02/18 09:16:58 Job still running ...
2023/02/18 09:17:28 Job still running ...
2023/02/18 09:17:58 Job still running ...
2023/02/18 09:18:29 Job still running ...
2023/02/18 09:18:59 Job still running ...
2023/02/18 09:19:29 Job still running ...
2023/02/18 09:19:59 Job still running ...
2023/02/18 09:20:29 Job still running ...
2023/02/18 09:20:59 Job still running ...
2023/02/18 09:21:29 Job still running ...
2023/02/18 09:21:59 Job still running ...
2023/02/18 09:22:29 Job still running ...
2023/02/18 09:22:59 Job still running ...
2023/02/18 09:23:29 Job still running ...
2023/02/18 09:23:59 Job still running ...
2023/02/18 09:24:29 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-18_01_15_58-1172981506071348071 failed
--- FAIL: TestXLang_Partition (549.08s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3165.609s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676709137201229607
--- FAIL: TestBigQueryIO_BasicWriteRead (4.50s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41091 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@xBCTwDdyBg"  is_bounded:BOUNDED  windowing_strategy_id:"w0@xBCTwDdyBg"}}  windowing_strategies:{key:"w0@xBCTwDdyBg"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@xBCTwDdyBg"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@xBCTwDdyBg"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@xBCTwDdyBg"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676709137201229607\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"xBCTwDdyBg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41091 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@xBCTwDdyBg"  is_bounded:BOUNDED  windowing_strategy_id:"w0@xBCTwDdyBg"}}  windowing_strategies:{key:"w0@xBCTwDdyBg"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@xBCTwDdyBg"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@xBCTwDdyBg"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@xBCTwDdyBg"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676709137201229607\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"xBCTwDdyBg"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 52 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000232f80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000232f80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005a0920?, 0xc000683680?}, {0x1136f49, 0x39}, {0xc0001a8000?, 0xa9bee0?, 0x1?}, {0xc000137b20, 0xf}, 0xc00002bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005a08c0?, 0xc000683680?}, {0xc0005b0300, 0x52}, {0x1?}, {0xc00002bea8, 0x2, 0x7f58e80f56d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137b20, 0xf}, {0xc0005b0300, 0x52}, {0xeb9520, 0xc0005fcf50})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000007d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000007d40, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.541s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f4ecadbe0ea5ea21252d1913ced6082e27ae654c831102637aecd8620faff9df
  Associated tags:
 - 20230218-083140
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-083140
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-083140].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f4ecadbe0ea5ea21252d1913ced6082e27ae654c831102637aecd8620faff9df].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a8b82806126685ead943cc962b000791acadf9c186b290e30d54271733ef9ca6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a8b82806126685ead943cc962b000791acadf9c186b290e30d54271733ef9ca6])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a8b82806126685ead943cc962b000791acadf9c186b290e30d54271733ef9ca6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a8b82806126685ead943cc962b000791acadf9c186b290e30d54271733ef9ca6].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d79d5ca75d2dee46c375772406467cfed70b06135c766129b7f720e6ad95d272]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d79d5ca75d2dee46c375772406467cfed70b06135c766129b7f720e6ad95d272])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d79d5ca75d2dee46c375772406467cfed70b06135c766129b7f720e6ad95d272
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d79d5ca75d2dee46c375772406467cfed70b06135c766129b7f720e6ad95d272].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 4m 39s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1303

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1303/display/redirect?page=changes>

Changes:

[noreply] Update Go SDK minimum Go version to 1.19 (#25545)

[noreply] Replace more uses of `ClassLoadingStrategy.Default.INJECTION` (#23210)

[noreply] Use WindowedValue.withValue on hot paths #21250 (#25519)

[noreply] Stop paying the iterator object creation tax in


------------------------------------------
[...truncated 1003.95 KB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-023206",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218022045",
            "environmentId": "oGbjJcLUUvbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-023206"
      }
    ]
  },
  "name": "go-testxlang_partition-847",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/18 03:16:30 Submitted job: 2023-02-17_19_16_29-13344772010705815880
2023/02/18 03:16:30 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-17_19_16_29-13344772010705815880?project=apache-beam-testing
2023/02/18 03:16:30 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-17_19_16_29-13344772010705815880
2023/02/18 03:16:30 Job state: JOB_STATE_PENDING ...
2023/02/18 03:17:00 Job still running ...
2023/02/18 03:17:30 Job still running ...
2023/02/18 03:18:00 Job still running ...
2023/02/18 03:18:30 Job still running ...
2023/02/18 03:19:00 Job still running ...
2023/02/18 03:19:30 Job still running ...
2023/02/18 03:20:00 Job still running ...
2023/02/18 03:20:30 Job still running ...
2023/02/18 03:21:00 Job still running ...
2023/02/18 03:21:30 Job still running ...
2023/02/18 03:22:00 Job still running ...
2023/02/18 03:22:30 Job still running ...
2023/02/18 03:23:00 Job still running ...
2023/02/18 03:23:31 Job still running ...
2023/02/18 03:24:01 Job still running ...
2023/02/18 03:24:31 Job still running ...
2023/02/18 03:25:01 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-17_19_16_29-13344772010705815880 failed
--- FAIL: TestXLang_Partition (549.41s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3169.776s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676687570378549708
--- FAIL: TestBigQueryIO_BasicWriteRead (5.54s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41125 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XXoaCrmUkM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XXoaCrmUkM"}}  windowing_strategies:{key:"w0@XXoaCrmUkM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XXoaCrmUkM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XXoaCrmUkM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XXoaCrmUkM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676687570378549708\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XXoaCrmUkM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41125 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@XXoaCrmUkM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@XXoaCrmUkM"}}  windowing_strategies:{key:"w0@XXoaCrmUkM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@XXoaCrmUkM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@XXoaCrmUkM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@XXoaCrmUkM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676687570378549708\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"XXoaCrmUkM"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 29 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000698840})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000698840})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480e60?, 0xc000117b80?}, {0x1136f49, 0x39}, {0xc0006f20c0?, 0xa9bee0?, 0x1?}, {0xc00049ac40, 0xf}, 0xc0006d9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480e00?, 0xc000117b80?}, {0xc000118840, 0x52}, {0x1?}, {0xc0006d9ea8, 0x2, 0x7f2df2983c68?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00049ac40, 0xf}, {0xc000118840, 0x52}, {0xeb9520, 0xc00049bf50})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000696820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000696820, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.577s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.047s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eb023ba54ea0d7006dc47e388fd428744b2d4c068ebb19d2a83580b7566818b5
  Associated tags:
 - 20230218-023206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-023206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230218-023206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eb023ba54ea0d7006dc47e388fd428744b2d4c068ebb19d2a83580b7566818b5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1c2b7bb52abaec1c8a68258a0f5dae79d611de764782b0d1e708415dab7f2c63]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230218022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1c2b7bb52abaec1c8a68258a0f5dae79d611de764782b0d1e708415dab7f2c63])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1c2b7bb52abaec1c8a68258a0f5dae79d611de764782b0d1e708415dab7f2c63
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:1c2b7bb52abaec1c8a68258a0f5dae79d611de764782b0d1e708415dab7f2c63].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:283d4ca4ff55d6ac0b19909fa8421d7952539c53f98bdafb506cd70a4bae384b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230218022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:283d4ca4ff55d6ac0b19909fa8421d7952539c53f98bdafb506cd70a4bae384b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:283d4ca4ff55d6ac0b19909fa8421d7952539c53f98bdafb506cd70a4bae384b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:283d4ca4ff55d6ac0b19909fa8421d7952539c53f98bdafb506cd70a4bae384b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 5m 12s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1302

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1302/display/redirect?page=changes>

Changes:

[noreply] Stop use of self hosted runners for some workflows. (#25542)

[noreply] Run prbot updates on hosted runners (#25544)

[noreply] prism-fixstatic (#25546)


------------------------------------------
[...truncated 597.85 KB...]
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217211550",
            "environmentId": "RpmyuIMzuTbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.46.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-213433",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-213433"
      }
    ]
  },
  "name": "go-testxlang_partition-343",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/17 22:21:46 Submitted job: 2023-02-17_14_21_46-8490481998827343871
2023/02/17 22:21:46 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-17_14_21_46-8490481998827343871?project=apache-beam-testing
2023/02/17 22:21:46 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-17_14_21_46-8490481998827343871
2023/02/17 22:21:46 Job state: JOB_STATE_PENDING ...
2023/02/17 22:22:17 Job still running ...
2023/02/17 22:22:47 Job still running ...
2023/02/17 22:23:17 Job still running ...
2023/02/17 22:23:47 Job still running ...
2023/02/17 22:24:17 Job still running ...
2023/02/17 22:24:47 Job still running ...
2023/02/17 22:25:17 Job still running ...
2023/02/17 22:25:47 Job still running ...
2023/02/17 22:26:17 Job still running ...
2023/02/17 22:26:47 Job still running ...
2023/02/17 22:27:17 Job still running ...
2023/02/17 22:27:47 Job still running ...
2023/02/17 22:28:17 Job still running ...
2023/02/17 22:28:47 Job still running ...
2023/02/17 22:29:17 Job still running ...
2023/02/17 22:29:47 Job still running ...
2023/02/17 22:30:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-17_14_21_46-8490481998827343871 failed
--- FAIL: TestXLang_Partition (555.17s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3223.469s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676669828830317878
--- FAIL: TestBigQueryIO_BasicWriteRead (12.00s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45709 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@NLsYoUpvNU"  is_bounded:BOUNDED  windowing_strategy_id:"w0@NLsYoUpvNU"}}  windowing_strategies:{key:"w0@NLsYoUpvNU"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@NLsYoUpvNU"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@NLsYoUpvNU"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@NLsYoUpvNU"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676669828830317878\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"NLsYoUpvNU"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45709 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@NLsYoUpvNU"  is_bounded:BOUNDED  windowing_strategy_id:"w0@NLsYoUpvNU"}}  windowing_strategies:{key:"w0@NLsYoUpvNU"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@NLsYoUpvNU"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@NLsYoUpvNU"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@NLsYoUpvNU"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676669828830317878\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"NLsYoUpvNU"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc000344300})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc000344300})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000500260?, 0xc0000bc280?}, {0x1136f49, 0x39}, {0xc0000f0180?, 0xa9bee0?, 0x1?}, {0xc00011e0b0, 0xf}, 0xc0005d3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000500200?, 0xc0000bc280?}, {0xc00004c840, 0x52}, {0x1?}, {0xc0005d3ea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011e0b0, 0xf}, {0xc00004c840, 0x52}, {0xeb9520, 0xc000536078})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102820, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	15.109s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.082s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.125s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.204s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:74663ed283720b9dc3fbd98db5438951d16dec1369f39de91802b0978f38c084
  Associated tags:
 - 20230217-213433
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-213433
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-213433].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:74663ed283720b9dc3fbd98db5438951d16dec1369f39de91802b0978f38c084].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217211550]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f9d8afd51519a786b583fd27fe08e0cc89cc209858374c1f9ad3483f916bb5d2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217211550] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f9d8afd51519a786b583fd27fe08e0cc89cc209858374c1f9ad3483f916bb5d2])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f9d8afd51519a786b583fd27fe08e0cc89cc209858374c1f9ad3483f916bb5d2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f9d8afd51519a786b583fd27fe08e0cc89cc209858374c1f9ad3483f916bb5d2].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217211550]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63d689b4f67844e12e09f2aee11aae189575aacd27aba8224bb8b40783275989]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217211550] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63d689b4f67844e12e09f2aee11aae189575aacd27aba8224bb8b40783275989])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63d689b4f67844e12e09f2aee11aae189575aacd27aba8224bb8b40783275989
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63d689b4f67844e12e09f2aee11aae189575aacd27aba8224bb8b40783275989].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 15m 48s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1301

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1301/display/redirect?page=changes>

Changes:

[elizaveta.lomteva] complete examples links fixed


------------------------------------------
[...truncated 554.47 KB...]
2023/02/17 16:23:53 Job still running ...
2023/02/17 16:24:23 Job still running ...
2023/02/17 16:24:53 Job still running ...
2023/02/17 16:25:23 Job still running ...
2023/02/17 16:25:53 Job still running ...
2023/02/17 16:26:23 Job still running ...
2023/02/17 16:26:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-17_08_18_22-10842768920528033474 failed
--- FAIL: TestXLang_Partition (554.88s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3248.986s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676648002906838011
--- FAIL: TestBigQueryIO_BasicWriteRead (5.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46435 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@bHjGBKByHt"  is_bounded:BOUNDED  windowing_strategy_id:"w0@bHjGBKByHt"}}  windowing_strategies:{key:"w0@bHjGBKByHt"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@bHjGBKByHt"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@bHjGBKByHt"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@bHjGBKByHt"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676648002906838011\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"bHjGBKByHt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46435 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@bHjGBKByHt"  is_bounded:BOUNDED  windowing_strategy_id:"w0@bHjGBKByHt"}}  windowing_strategies:{key:"w0@bHjGBKByHt"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@bHjGBKByHt"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@bHjGBKByHt"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@bHjGBKByHt"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676648002906838011\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"bHjGBKByHt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 29 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00033c580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00033c580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000488f60?, 0xc0004a9680?}, {0x1136f49, 0x39}, {0xc000204000?, 0xa9bee0?, 0x1?}, {0xc00048acc0, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488f00?, 0xc0004a9680?}, {0xc000116840, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7f23246f2040?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048acc0, 0xf}, {0xc000116840, 0x52}, {0xeb9520, 0xc00048bfd0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ca820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ca820, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.413s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.069s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-153155
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-153155
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e081ef3ce5677daa42f981a2dbb79b51c3d7c7b8f07af5390c49e7c3d4bcdeda
Deleted: sha256:2cd9e8e17692970ccf956d8bdd0f3b5eca6b6e4bcfc3b98a62af7fb8135a0811
Deleted: sha256:b893661f910d712e2387d65a8b51fbcc02c92bcc7711d28666520f9f32ba5c66
Deleted: sha256:d943c69cb25e5bce73b981c5633cbf7f18146372e8f6344c4600722fb4c034e2
Deleted: sha256:0d8204a606814e676570e50290e940811c835a15f1de26b13de8e1ecc5479f8b
Deleted: sha256:fd2e02406683818faa4382358cbec5b41e408ffc39287cd6781c7d96ec64525d
Deleted: sha256:570db2c9f22050aa7bb3fc2df916fc1a6d839fa8df30a513809ea35369a75831
Deleted: sha256:f35cb45b1dc128f8cb8ababa80d55f81000de3dc92974ab3146c88e980bca72f
Deleted: sha256:d149b8623b0a03d51b572e01882fab13a026179112a4109cc0dcd1d3bd056ea9
Deleted: sha256:6c97fb1fbcc690bb669ed6190301a3b58da8d5b54a641d4cc9b8a6ed4381a93e
Deleted: sha256:060514f8268da8c14f6ed4728650abee4bd81d116ee4089173516361202bb65e
Deleted: sha256:32d4bd50fcb07f6bdab65669e38cd88d56de50f948c05b9a16e807c88b613a2d
Deleted: sha256:8335aea59176f2b735eb1331ccd5636ab1953142ffc8a2f22ab60054fccfee8c
Deleted: sha256:31e8672be969707b82f71699cc0129b9e09f0475381abad4e7f43ecae988c6d2
Deleted: sha256:816b4059d6ed762b3ce33ac52d886b1b13473d71298542254e0ef348ec2cee14
Deleted: sha256:28eb3cfb92a45a9937f5f705e29a538cf69c79222e2167006c1f756189ffd8e3
Deleted: sha256:c4b6dc36d616d9bc8864ceffe4d6050446d98c0e1611993b81ba1fe266ae71ae
Deleted: sha256:e63cefde1480bd533c5ebad3573b2b544cbd00d834c285ce893259039e66d34c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-153155
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e081ef3ce5677daa42f981a2dbb79b51c3d7c7b8f07af5390c49e7c3d4bcdeda
  Associated tags:
 - 20230217-153155
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-153155
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-153155].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e081ef3ce5677daa42f981a2dbb79b51c3d7c7b8f07af5390c49e7c3d4bcdeda].
$ rm -rf /tmp/tmp.dyem3tsJqL
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217151939
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217151939]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217151939] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:eccbbf9c129fadb99e0f8ddf9dc89c45e56ca98e36505df33d72506b3dfef79b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217151939
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92
Deleted: sha256:c82f7acc61414338e209a3ac98e1d8080e632aac48bbb2bb15aa535d417a722c
Deleted: sha256:63361aa43a3fe6e92b01f777a59a8c08a87a09a85ba39e2c134e078510198ca9
Deleted: sha256:56b3e4b9de39d9f41131ebf8d19c98a6dcb7f86c4ea90c11d7e2703abfba7bf6
Deleted: sha256:2340452e04c14ea035147e47c7c3bc5617ebbbd36ee9e541ad9d0463ef36ce7f
Deleted: sha256:9968169edb2bb6eff0dca269485e4da7fd735ab2bd4e6594c7571fe04a233f23
Deleted: sha256:c1e665b53289a3f3478da3afca6fae8c3a5f8bc7a7d50c657de3e5e31de9dfa2
Deleted: sha256:536d30c10a74a695272527e23b662fcfac7efc9f406267d62d73c6eacf1d8636
Deleted: sha256:92fb08d0127b971863b13632ea52553baa00f3312651e3eedae625c01f07d2fa
Deleted: sha256:7b13e8f064a0118f3aae33241f0aa93f45d7e110dc74b2ece323ae6def6e36df
Deleted: sha256:a648d1eeb54b074d4b551a7591c52fb494be2be25d665f5f9d60cb1993b3450d
Deleted: sha256:0fdd65c26b80c46c658ace9f636193638b28f936557eac997cf92f0b638f5bfc
Deleted: sha256:77575e1d66927919593cc9d8b2b863bf52b0264d988342b3fe7a30475f4c03f5
Deleted: sha256:2a4dec7c9b73a09035b4ce4f60b163b7b0ba966f98128d193d835769f6a248b0
Deleted: sha256:fbe169b099fe29d233515a51164a852722a2e48e6adcdaba346f127e6b0c7b83
Deleted: sha256:5efb44cfe556372fd80bf70a521dc5270f28a0095c0d752e287ca2d6f45b51b0
Deleted: sha256:8345b9b731fc11b3fb3cf88a226c66249aa1bc6c2f5397d4133760a09c5c533a
Deleted: sha256:9f5936f70ffe58971f38872b97ff223b67a1af025d1fbb2e87bd6ed8a221918d
Deleted: sha256:f29a481e86c9a8b82e3d31883d9cde059512e32f2c3c30c8d9aeeb422cc6d4e4
Deleted: sha256:db32351a7ee153bf75f3a3ede6dc1adc45400143290c7ad47c2480857b0d6f74
Deleted: sha256:bc81463daf076f086f466c6d05e9ff9ecdd4e7e5b5ea17761a99ceebd1b58a20
Deleted: sha256:06630544c63de3383eb51487cdde8fbfbb7cedd2f755aa3d0d45dad74ff412b4
Deleted: sha256:68812a9dc9dd53496cf3e3157dd8705f33a61182c9c821f74ecd348f543dae44
Deleted: sha256:49a576538526ae5880494b3d41f7d2a440c464db383ccdbff67dd36f3a619390
Deleted: sha256:1f6b23df4a545c0336edcaf4226b34d1ac52e49a63be763316e406b7e600728b
Deleted: sha256:3aebb57ba6d57b7219366156423ffd2aa0ad747218ea1eccb5ca8cc315ef8e83
Deleted: sha256:e5f230398d837694a49469635835723daf84c2687d8258e04bb65d86ab10a2ba
Deleted: sha256:9996d35db95646d98a8e66f87b992a7f44676aecf5137f19ad8c778c823a2135
Deleted: sha256:9513374810c4e95c623acf196f2917e52b80f727576fda490aadda79bdf6ba99
Deleted: sha256:036ba2d90fd353aa510a27fdb97e39a549ca00b42914380ddc09ea3bf9f4946e
Deleted: sha256:c0f396d9ad08cf92f2cb03dd265dd3f3de08019da8a51cf7ff4fa8a3f5e42185
Deleted: sha256:2a6aa3646e5a7b7eccec87c57707cbccd2bb07f08651074dbdcb0695ab9abc82
Deleted: sha256:f32b21d7db473d7fdef2f3ade692a6fa2013a2afdca6419a35b09b88c0678934
Deleted: sha256:9e9bd3899292758b60c9f5d947bafb20bf7ee23fb509732ce789738ac2d9cefc
Deleted: sha256:b22aad942366df99a741d34b60ba61e87d7c7f78c588903d35e2f0646502d95e
Deleted: sha256:b22b7ce96f7037acada12cbb8a2905035289073ce049d612e435c15df3f96884
Deleted: sha256:ff91ba6c94d1503f8922d8651712b3ac3eecf8b20bad35119ae6def3257bec0f
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217151939]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217151939] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b2cc8c245ef6df5c8ec25e656a12b6653fdc0d537f176090b757297a61f50c92].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1527614.
Stopping expansion service pid: 1527615.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 11s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1300

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1300/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217083020",
            "environmentId": "EjXewUsEIebeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219"
      }
    ]
  },
  "name": "go-testxlang_partition-541",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/17 09:31:25 Submitted job: 2023-02-17_01_31_24-5928700724889931907
2023/02/17 09:31:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-17_01_31_24-5928700724889931907?project=apache-beam-testing
2023/02/17 09:31:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-17_01_31_24-5928700724889931907
2023/02/17 09:31:25 Job state: JOB_STATE_PENDING ...
2023/02/17 09:31:55 Job still running ...
2023/02/17 09:32:25 Job still running ...
2023/02/17 09:32:55 Job still running ...
2023/02/17 09:33:25 Job still running ...
2023/02/17 09:33:55 Job still running ...
2023/02/17 09:34:25 Job still running ...
2023/02/17 09:34:56 Job still running ...
2023/02/17 09:35:26 Job still running ...
2023/02/17 09:35:56 Job still running ...
2023/02/17 09:36:26 Job still running ...
2023/02/17 09:36:56 Job still running ...
2023/02/17 09:37:26 Job still running ...
2023/02/17 09:37:56 Job still running ...
2023/02/17 09:38:26 Job still running ...
2023/02/17 09:38:56 Job still running ...
2023/02/17 09:39:26 Job still running ...
2023/02/17 09:39:56 Job still running ...
2023/02/17 09:40:26 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-17_01_31_24-5928700724889931907 failed
--- FAIL: TestXLang_Partition (580.79s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3478.086s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676623386268706411
--- FAIL: TestBigQueryIO_BasicWriteRead (5.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36403 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@OjjGwACsda"  is_bounded:BOUNDED  windowing_strategy_id:"w0@OjjGwACsda"}}  windowing_strategies:{key:"w0@OjjGwACsda"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@OjjGwACsda"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@OjjGwACsda"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@OjjGwACsda"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676623386268706411\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"OjjGwACsda"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36403 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@OjjGwACsda"  is_bounded:BOUNDED  windowing_strategy_id:"w0@OjjGwACsda"}}  windowing_strategies:{key:"w0@OjjGwACsda"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@OjjGwACsda"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@OjjGwACsda"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@OjjGwACsda"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676623386268706411\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"OjjGwACsda"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00048da00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00048da00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7a20?, 0xc00049b860?}, {0x1136f49, 0x39}, {0xc0000f00c0?, 0xa9bee0?, 0x1?}, {0xc000492fe0, 0xf}, 0xc000247d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a79c0?, 0xc00049b860?}, {0xc00013e3c0, 0x52}, {0x1?}, {0xc000247ea8, 0x2, 0x7f4852cae308?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000492fe0, 0xf}, {0xc00013e3c0, 0x52}, {0xeb9520, 0xc00025c2f0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ad6c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ad6c0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.612s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.039s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5ecd50fcaaaee650644e0b4d564ddc073a965e01fd22a22344d1c5633873a83a
Deleted: sha256:ad9fe80720e7f81d7341d77afda58695f511d6de5d9e9ebc75d370959b051ba7
Deleted: sha256:ea8b72cb843268b840eca238067d47d2b11c8f0ebf6b6ca97bbb64567cb1f88d
Deleted: sha256:cbf1eee4e6268d35194ce11f49dc8182e78460f022ecc1c907bc131c9e3d1b0b
Deleted: sha256:322cacfb919d8a7356cca4be0c3c98a8bb5aeb852a81aaad0cde4cb26f8499ab
Deleted: sha256:ae501b939dbd62f93d28dd94793946e7f0ad176ee8ee075be46795959fada483
Deleted: sha256:f973bb54df78ec8f556db2c5838e24b6d9099e05a816dcecb7d9952cd253de7b
Deleted: sha256:242a39825c5bb35ac82a654d995eb13f8b82a1c0470b1ea12198f6deb93d6561
Deleted: sha256:39bbc26ee9f377e61c14ec58e17aa5178c68147cbf099aea01cb33fcda3200b7
Deleted: sha256:986702e4dc077af7f830fa36cc17d4da9523e79356adebb7ec146c90ae2a338a
Deleted: sha256:df8a963bd8da58dbcb6ec71493c86293e571bfaedec4920485a672cad5769f7c
Deleted: sha256:9ca2133b73dcbffa64dd69b6f0dac6fc0b6ffb158e9b80f345d240d5896262b4
Deleted: sha256:13a3c2f61cdbf40bc63c6fc44f1b26f13499b7bcd306266b9705a20c8d2bde96
Deleted: sha256:69e4fbc591d096a6dca799011b3360d367e15c5615bcca02e57b850a5b352744
Deleted: sha256:40c1704d4921cebc51c89e75cb61010219b6ded6d23a7e73a812f34f464362ed
Deleted: sha256:e504b5c93090c53730be08b0fddcd37639d236dc2fbfed41e5651a24ef37dbd3
Deleted: sha256:d2e506f8700901dc09315113266ac8a828434f1e6f2a397a86c12c9c1bcdd401
Deleted: sha256:e81e3b0e556f03d0db52b568685fe274c7e29d401fdf2595db0e00c68c152362
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5ecd50fcaaaee650644e0b4d564ddc073a965e01fd22a22344d1c5633873a83a
  Associated tags:
 - 20230217-084219
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-084219].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5ecd50fcaaaee650644e0b4d564ddc073a965e01fd22a22344d1c5633873a83a].
$ rm -rf /tmp/tmp.pTv57rpRn8
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217083020
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217083020]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217083020] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e6617bb9395ae27bab12ede10f9294857b58d93f5fb0dd6f643ea47ed27d7ede].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217083020
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217083020]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217083020] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:954367f5a7aef01f8d5f129d82449384e55384420cf217d71df14b5097398d29].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1680350.
Stopping expansion service pid: 1680351.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 11m 1s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1299

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1299/display/redirect?page=changes>

Changes:

[noreply] update GCP cloud libraries BOM to 26.8.0 (#25470)

[noreply] Fix interface{} in iter& emit type of DoFn in Go (#25203)

[noreply] Task #25064: Python SDK Data sampling implementation (#25093)

[noreply] Add support for all Java based portable runners to consume elements

[noreply] Swap Java SDK container to use eclipse-temurin as the base instead of

[noreply] Update BigQueryIO documentation with details on how to override the

[noreply] Support Avro GenericRecord as a valid format for StorageWrite API on


------------------------------------------
[...truncated 1.02 MB...]
2023/02/17 03:23:28 Job still running ...
2023/02/17 03:23:58 Job still running ...
2023/02/17 03:24:28 Job still running ...
2023/02/17 03:24:58 Job still running ...
2023/02/17 03:25:28 Job still running ...
2023/02/17 03:25:58 Job still running ...
2023/02/17 03:26:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-16_19_17_57-8554693055503494914 failed
--- FAIL: TestXLang_Partition (550.43s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3237.230s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676601188965126759
--- FAIL: TestBigQueryIO_BasicWriteRead (4.09s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33535 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@HjwOrnYDId"  is_bounded:BOUNDED  windowing_strategy_id:"w0@HjwOrnYDId"}}  windowing_strategies:{key:"w0@HjwOrnYDId"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@HjwOrnYDId"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@HjwOrnYDId"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@HjwOrnYDId"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676601188965126759\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"HjwOrnYDId"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33535 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@HjwOrnYDId"  is_bounded:BOUNDED  windowing_strategy_id:"w0@HjwOrnYDId"}}  windowing_strategies:{key:"w0@HjwOrnYDId"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@HjwOrnYDId"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@HjwOrnYDId"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@HjwOrnYDId"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676601188965126759\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"HjwOrnYDId"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2893)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1950)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc00002f100})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc00002f100})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168cc0?, 0xc00049a050?}, {0x1136f49, 0x39}, {0xc0000dc0c0?, 0xa9bee0?, 0x1?}, {0xc000043af0, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168be0?, 0xc00049a050?}, {0xc00004c840, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe78280?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043af0, 0xf}, {0xc00004c840, 0x52}, {0xeb9520, 0xc00048c1a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ccea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ccea0, 0x1168f40)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.128s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.031s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-023230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-023230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:74cd63659395bf36a826287ba63e76b3cf27789da2e135c8be7a7b2483f923b2
Deleted: sha256:bb1511895eb38ae3c5cdbecb9b1f0dbc3a0a1b6b55c20d48fdc45ffa67ad12bb
Deleted: sha256:664bd4eb61b661e2dfd8a16940e7ca3d8cbf4da3bd425dae3d668065208d48a2
Deleted: sha256:d31666efa9cd861b6cc5c866af26c175a40dd81d4e343ea76bdb6ad6edb66be8
Deleted: sha256:99be5094c863f7a0df735817161ec330e6839baa0df6f057307659fda8b1cd86
Deleted: sha256:43c3f3d1eec2cd55e968626fc698f11e8bfc3152caf15f3d345b2ad1852c0111
Deleted: sha256:7ac3db040639b4fd54b6317b9ce973737b41b40f09f529f4b00b1d08ce437771
Deleted: sha256:b4f9a4eb752ac2768de4d87fa509db5f692503552c3094206e3b289f62a1e984
Deleted: sha256:7d1c381c64761e9159d1ff354ea54dff4f6ebbce4653f68376d0aa9b7f50607f
Deleted: sha256:a04448be1426b4d046fc384333ce762aef83c519a4254a79c9ebe9acce49940c
Deleted: sha256:771ca67e1df6f8259744f0d8753805cc43126c0210ecad745537a996c2e3bd26
Deleted: sha256:c4453e9c4cffa041a6e2d80d26e0917089e7671495c1d2d6d3c32510d64651d4
Deleted: sha256:9fde5feb5fe472fa9d50d03bb4d388981671326326fb53a1681cfa6ea3c45bfd
Deleted: sha256:b4c3c011e0e0e4299738f72fd1bccc8d553b1a8789faa1ef4947c98a37408b6b
Deleted: sha256:8415f8326b47b7deb93314fdb407e98f8e800dea1ec9e8405c08b8c4dcdab7bc
Deleted: sha256:383a6c919fde63363de1a118bc2786664c5cfcbb626cb489047adc66b30129e9
Deleted: sha256:a0c5354ba6d6e5587841e8f95791f72b3e97a3375f36e5f1ee1a941b835d4302
Deleted: sha256:ce1a9249379be1f6edea2c920645e6014c81d920848b91c2c8781c3008623ea2
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-023230
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:74cd63659395bf36a826287ba63e76b3cf27789da2e135c8be7a7b2483f923b2
  Associated tags:
 - 20230217-023230
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-023230
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230217-023230].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:74cd63659395bf36a826287ba63e76b3cf27789da2e135c8be7a7b2483f923b2].
$ rm -rf /tmp/tmp.TVelXnEMQl
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217022043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217022043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230217022043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d9506526bd19bc4bb1b1d164bfd82189d4ee01d55525e178872d7ec24fc78513].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217022043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657
Deleted: sha256:0a084892f5d590b7115d34d1378cb2635ad71c5ba53c2b07e3b6f964731871ea
Deleted: sha256:58a0d66518752a34759211ab616f1c62c7df2e613c08db11ffcd314fa32c89cb
Deleted: sha256:2bfe112fbabc10c8cc941c4a98d13a37c199aa44c2192cd048548ece1a266ac0
Deleted: sha256:a8090f589c810c065dda3a479d9e6a43ec51913d5c735e3b3ab93b08e7990322
Deleted: sha256:f5e5545f65107689a11600d869e427ec77a077cd51e87c3d4b1e599d222b74a9
Deleted: sha256:da84c4b0b45b9dbb6a3f3879facc2cf3af160751756a20710cac4d150e5c18c0
Deleted: sha256:abc52eeb01e928680289f5ecd1600da0dfd99e3a35726ed09a3f99714b3ee69b
Deleted: sha256:998b1e2af1b577386a0d8f57d3af1ffc6526f4d60aa2ddef97b8aeec5e26ddab
Deleted: sha256:076afa14ec0d41fe1c499fd5a1b325dec6c87e466d18f0df5ef7dc748eaed011
Deleted: sha256:8ab045036f9c94ec9ae75cfc7368e3b479e5e31f075ed69b9e8be5552c5d98c2
Deleted: sha256:97dc3bd21119d477fce7acb89a9fa656c4d580231bc65fa63d51d178a9c79acc
Deleted: sha256:c751eb6b3b9f8c964e751aff0bd8b84747847ad09854298d7e08d221d968ba3e
Deleted: sha256:53068cfa018e1e594de79c6b430f53a65fcf4484d181694ee333b6a84404048a
Deleted: sha256:599997be75942b8f6d21a4ecc89cdaf457b21b9054d9fea9994f00b699d39e1f
Deleted: sha256:a05cd809f826848a9b48a4b703637defcb2fa833843cc70a1169f3d916079407
Deleted: sha256:22021b9e23457c2955b4db3b0a1ba0a5d9e2635915acaddeec3b4ba67749da56
Deleted: sha256:ee4450062e4c97db85ac59a3a450a1c2cbba14b3ae48d5c2ccabfb3ed43f5a7d
Deleted: sha256:370407b6484df853f92ce113a1dbd78eb40865d1fee61041c27b39d41cfb0d75
Deleted: sha256:57a787514b653420676e1a87dcd37b2ac03e491f379b07b2295665367baa0bdc
Deleted: sha256:05f09d51ea0f7b2e8b26007283437140e47866a2ad32a6fb498350a5fa837208
Deleted: sha256:4677e9310c9a670dc471f1fc789c2cb6bbd6f9fce8d026b935901abd5a78cad5
Deleted: sha256:c2389ab7c8adde2fb2f583348701ce8b10ed53cbce6a293cf68786dbd69a882e
Deleted: sha256:1d153ed7ba09abe1a381e7445fc108794a22216b54c75ede9ee43da8aad4acb4
Deleted: sha256:44a6254eda77c14a27695a426348442fd25af3d352652d711674342b2942ca1b
Deleted: sha256:5d0e7586417c281ae4b081a325de41a2dd640265392af2d93433e38111e3cb50
Deleted: sha256:979b7d8b25eabdfb99206ca1053502f0c96d52c3bec1067e102027bceb9c44f3
Deleted: sha256:659bf3d733346f684624598a5e424e2ad1d3153af95aa1ed1455c374087d9af9
Deleted: sha256:1ee02a96e06da7ce591110511a1485bbf628a52ed4ccb38bf583b5b49f19e29b
Deleted: sha256:a082fa80fb54d24e600996e565e35ee3394c06261ac7068c3988e4689f274b13
Deleted: sha256:8fc8ed7bba3b87f8f6c1d0630057028cf42729093c7a1bfee85038da3f382b5e
Deleted: sha256:3b0ed76c2863a65de8d57002f07462228eace50eb6d5ee2c290384bdbaf09d08
Deleted: sha256:c74083c3916969ef4d8d751417f5b582640feecebe044ca60b4a89ef85ea6bd8
Deleted: sha256:5c55c9b07a2ef0af374238f678b924f93921c537acfdc95a051e9f9d33909072
Deleted: sha256:7fe9a57323721264175c5627725b3a832e1ca091dafc19dcf127cc507c4a896c
Deleted: sha256:a83ec162914fd6cea9affce19e1d59b3697a3cf9aeb340b7d8b61f8eccbe9a1f
Deleted: sha256:a868b408f30645d05436c26d3f4698fe84a43d9bdee35227d5adad466a440b0d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217022043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230217022043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:66f8a571414f0c01f78bebcb6c7144ef3d51e2d94e07bee1f7cd867f719fa657].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 444202.
Stopping expansion service pid: 444203.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 43s
216 actionable tasks: 174 executed, 30 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1298

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1298/display/redirect?page=changes>

Changes:

[noreply] TFMA notebook showing ExtractEvaluateAndWriteResult Tranfsorm (#25381)

[noreply] Fix whitespace check (#25514)

[noreply] Add back links removed in #24744 (#25513)

[bvolpato] Fix pull_licenses_java returning 404 from opensource.org

[noreply] [#24789][prism] internal/jobservices metrics + tests (#25497)

[noreply] [Go SDK]: Allow SDF methods to have context param and error return value

[noreply] Move closing milestone out of PMC-only tasks (#25516)


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230216-203348",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230216202051",
            "environmentId": "AGYDabDMXUbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230216-203348"
      }
    ]
  },
  "name": "go-testxlang_partition-766",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/16 21:20:04 Submitted job: 2023-02-16_13_20_03-17350028137611695406
2023/02/16 21:20:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-16_13_20_03-17350028137611695406?project=apache-beam-testing
2023/02/16 21:20:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-16_13_20_03-17350028137611695406
2023/02/16 21:20:04 Job state: JOB_STATE_PENDING ...
2023/02/16 21:20:34 Job still running ...
2023/02/16 21:21:04 Job still running ...
2023/02/16 21:21:34 Job still running ...
2023/02/16 21:22:04 Job still running ...
2023/02/16 21:22:34 Job still running ...
2023/02/16 21:23:04 Job still running ...
2023/02/16 21:23:34 Job still running ...
2023/02/16 21:24:04 Job still running ...
2023/02/16 21:24:34 Job still running ...
2023/02/16 21:25:04 Job still running ...
2023/02/16 21:25:34 Job still running ...
2023/02/16 21:26:04 Job still running ...
2023/02/16 21:26:34 Job still running ...
2023/02/16 21:27:04 Job still running ...
2023/02/16 21:27:34 Job still running ...
2023/02/16 21:28:05 Job still running ...
2023/02/16 21:28:35 Job still running ...
2023/02/16 21:29:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-16_13_20_03-17350028137611695406 failed
--- FAIL: TestXLang_Partition (580.31s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3295.160s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676579687507926624
--- FAIL: TestBigQueryIO_BasicWriteRead (5.88s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34431 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@HoRyfTWUEt" is_bounded:BOUNDED windowing_strategy_id:"w0@HoRyfTWUEt"}} windowing_strategies:{key:"w0@HoRyfTWUEt" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@HoRyfTWUEt" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@HoRyfTWUEt" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@HoRyfTWUEt" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676579687507926624\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"HoRyfTWUEt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34431 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@HoRyfTWUEt" is_bounded:BOUNDED windowing_strategy_id:"w0@HoRyfTWUEt"}} windowing_strategies:{key:"w0@HoRyfTWUEt" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@HoRyfTWUEt" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@HoRyfTWUEt" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@HoRyfTWUEt" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676579687507926624\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"HoRyfTWUEt"
expansion response error
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 53 [running]:
testing.tRunner.func1.2({0xf6b600, 0xc0000bc9c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf6b600, 0xc0000bc9c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6c80?, 0xc0001179f0?}, {0x1136f16, 0x39}, {0xc00015e180?, 0xa9b920?, 0x1?}, {0xc0005aae30, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6c20?, 0xc0001179f0?}, {0xc0005bc3c0, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f2a15674800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0005aae30, 0xf}, {0xc0005bc3c0, 0x52}, {0xeb9520, 0xc000136410})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000338680)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000338680, 0x1168f00)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.910s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.058s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7d1c42bc5b8e1ce2291327f445ccde23b396f52063359041fc9d2f8b8f4e231c
  Associated tags:
 - 20230216-203348
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230216-203348
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230216-203348].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7d1c42bc5b8e1ce2291327f445ccde23b396f52063359041fc9d2f8b8f4e231c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230216202051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:667ebf874adae940c518810237c22b5dfbf2d73880e4385217e9826f7526a185]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230216202051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:667ebf874adae940c518810237c22b5dfbf2d73880e4385217e9826f7526a185])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:667ebf874adae940c518810237c22b5dfbf2d73880e4385217e9826f7526a185
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:667ebf874adae940c518810237c22b5dfbf2d73880e4385217e9826f7526a185].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230216202051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b434ffdcc84df38234e9a1f4f0da4171726ee484be4583ba6ca65e99ae73359]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230216202051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b434ffdcc84df38234e9a1f4f0da4171726ee484be4583ba6ca65e99ae73359])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b434ffdcc84df38234e9a1f4f0da4171726ee484be4583ba6ca65e99ae73359
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7b434ffdcc84df38234e9a1f4f0da4171726ee484be4583ba6ca65e99ae73359].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 16s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1297

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1297/display/redirect?page=changes>

Changes:

[noreply] Fix beam.Row.__eq__ for rows with trailing columns (#23876)


------------------------------------------
[...truncated 862.25 KB...]
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.2
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.6
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.6.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.3.2
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.4
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.5.1
Werkzeug==2.2.3
wheel==0.38.4
wrapt==1.14.1
zipp==3.13.0
zstandard==0.19.0
Removing intermediate container d178f416e7bf
 ---> 24245457f002
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 2e86834284e7
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> a86f80eb8519
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> fe3bc9bee2b3
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 972c36f4b700
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 0997a82324cd
Removing intermediate container 0997a82324cd
 ---> 9e3dd9f7202c
Step 22/32 : FROM beam as third_party_licenses
 ---> 9e3dd9f7202c
Step 23/32 : ARG pull_licenses
 ---> Running in 6f3b88a5f034
Removing intermediate container 6f3b88a5f034
 ---> 843f37aa7c0e
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 32ef2553daa1
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 5bdfd31e8045
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 4f949b9b41e6
Removing intermediate container 4f949b9b41e6
 ---> bcc64c568378
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> a0616798ead0
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 78b12e17cb02
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=c240fdb591c02ecd23ef8092867e6a49adcfcc1565f47931e34c437e004efbde
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
INFO:root:Successfully pulled licenses for 136 dependencies
Skip pulling license for  bs4
Removing intermediate container 78b12e17cb02
 ---> 70a7cbc8f72f
Step 29/32 : FROM beam
 ---> 9e3dd9f7202c
Step 30/32 : ARG pull_licenses
 ---> Running in 8ddc134bb42b
Removing intermediate container 8ddc134bb42b
 ---> 250465543343
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> d6e7f425459e
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 29b7449e0bbe
Removing intermediate container 29b7449e0bbe
 ---> b1b8e44bdbf0
Successfully built b1b8e44bdbf0
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
0347ac043500: Preparing
71ddd501c9bd: Preparing
d0fc50a85101: Preparing
78c731758f70: Preparing
4f520a6ac9f1: Preparing
036adf158064: Preparing
665a84a6f6a7: Preparing
4fbf6b129b00: Preparing
5d50daf58f7d: Preparing
6afdc20b875c: Preparing
8697cf5ed783: Preparing
18599759782a: Preparing
6a83adbc5aff: Preparing
72da44bb966b: Preparing
4568910c2995: Preparing
26eafd96cbc2: Preparing
28a3fbb997db: Preparing
17efc79ac0fe: Preparing
0b6859e9fff1: Preparing
11829b3be9c0: Preparing
dc8e1d8b53e9: Preparing
9d49e0bc68a4: Preparing
8e396a1aad50: Preparing
18599759782a: Waiting
6a83adbc5aff: Waiting
72da44bb966b: Waiting
4568910c2995: Waiting
26eafd96cbc2: Waiting
28a3fbb997db: Waiting
17efc79ac0fe: Waiting
0b6859e9fff1: Waiting
11829b3be9c0: Waiting
dc8e1d8b53e9: Waiting
9d49e0bc68a4: Waiting
8e396a1aad50: Waiting
665a84a6f6a7: Waiting
4fbf6b129b00: Waiting
5d50daf58f7d: Waiting
6afdc20b875c: Waiting
8697cf5ed783: Waiting
036adf158064: Waiting
d0fc50a85101: Pushed
4f520a6ac9f1: Pushed
78c731758f70: Pushed
0347ac043500: Pushed
4fbf6b129b00: Pushed
5d50daf58f7d: Pushed
71ddd501c9bd: Pushed
665a84a6f6a7: Pushed
6a83adbc5aff: Pushed
72da44bb966b: Pushed
4568910c2995: Layer already exists
26eafd96cbc2: Layer already exists
28a3fbb997db: Layer already exists
17efc79ac0fe: Layer already exists
0b6859e9fff1: Layer already exists
11829b3be9c0: Layer already exists
dc8e1d8b53e9: Layer already exists
9d49e0bc68a4: Layer already exists
8e396a1aad50: Layer already exists
8697cf5ed783: Pushed
036adf158064: Pushed
6afdc20b875c: Pushed
18599759782a: Pushed
20230216142047: digest: sha256:09a96a9b47292378f8158f251122e928da6070b1668923f2dc786dee1c78e0d6 size: 5156

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 14m 42s
207 actionable tasks: 134 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/7inrmoeffgli4

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1296

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1296/display/redirect>

Changes:


------------------------------------------
[...truncated 817.51 KB...]
apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
astunparse==1.6.3
attrs==22.2.0
beautifulsoup4==4.11.2
bs4==0.0.1
cachetools==4.2.4
certifi==2022.12.7
cffi==1.15.1
charset-normalizer==3.0.1
click==8.1.3
cloudpickle==2.2.1
crcmod==1.7
cryptography==39.0.1
Cython==0.29.33
deprecation==2.1.0
dill==0.3.1.1
docker==6.0.1
docopt==0.6.2
exceptiongroup==1.1.0
execnet==1.9.0
fastavro==1.7.1
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.78.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.5.0
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.1
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.1
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.2
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.68.1
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.2
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.6
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.6.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.3.2
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.4
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.5.1
Werkzeug==2.2.3
wheel==0.38.4
wrapt==1.14.1
zipp==3.13.0
zstandard==0.19.0
Removing intermediate container ba8acdb636ed
 ---> c2d3e6282fd5
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 129a19f4d9f1
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> b0576e43c3ff
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 276ba7c5bfe8
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> c5e3b4283980
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 115f71fbdb73
Removing intermediate container 115f71fbdb73
 ---> da1ab4ec8a84
Step 22/32 : FROM beam as third_party_licenses
 ---> da1ab4ec8a84
Step 23/32 : ARG pull_licenses
 ---> Running in eb42823c5122
Removing intermediate container eb42823c5122
 ---> 7653e8795f75
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 5a30f34ba9b6
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 9339b8b2256c
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 3b3d94b77831
Removing intermediate container 3b3d94b77831
 ---> adaf61db1a43
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> fb9704c844c0
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 41e600b99a5c
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=3d3ea84e00e0c47a3988ba81576afd85832db708264da51b6b6f9ab6d93acf53
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 41e600b99a5c
 ---> a6d13b57bfd2
Step 29/32 : FROM beam
 ---> da1ab4ec8a84
Step 30/32 : ARG pull_licenses
 ---> Running in bfa100e01d9b
Removing intermediate container bfa100e01d9b
 ---> 923b5cee77ec
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 012a693e580c
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 897df62b54c5
Removing intermediate container 897df62b54c5
 ---> 51914752c47c
Successfully built 51914752c47c
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 12m 40s
207 actionable tasks: 134 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1295

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1295/display/redirect?page=changes>

Changes:

[noreply] [#24789][prism] internal/coders.go and tests (#25476)

[noreply] Update documents for 2.45 (#25407)

[noreply] Update documents for 2.45 (#25500)

[noreply] Update python container images (#25475)


------------------------------------------
[...truncated 852.97 KB...]
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.2
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.6
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.6.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.3.2
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.4
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.5.1
Werkzeug==2.2.3
wheel==0.38.4
wrapt==1.14.1
zipp==3.13.0
zstandard==0.19.0
Removing intermediate container aaa38de8c817
 ---> ee5ece6a37b2
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 9a25624a5df3
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> d9952a1e1c28
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> e8df2713672a
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 85087bfec8f2
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 1b86d26836d7
Removing intermediate container 1b86d26836d7
 ---> 696bb8679290
Step 22/32 : FROM beam as third_party_licenses
 ---> 696bb8679290
Step 23/32 : ARG pull_licenses
 ---> Running in 30e14de4c940
Removing intermediate container 30e14de4c940
 ---> 157eb2d4ce46
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 155c099f61ff
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 4e8c10170cf3
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in cba5c8f894ac
Removing intermediate container cba5c8f894ac
 ---> 912970591ca0
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> bcfc82edeaeb
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 872acd4c94b5
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=31569cdcad3b2742e86166519ecdef2531c60de5c42e19b42c65e6f7baf345d0
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 872acd4c94b5
 ---> d62b3b9f0265
Step 29/32 : FROM beam
 ---> 696bb8679290
Step 30/32 : ARG pull_licenses
 ---> Running in 93d7ce057834
Removing intermediate container 93d7ce057834
 ---> c9d89a7f1f12
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> bd18ec6fbd02
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 29cd4cecf16d
Removing intermediate container 29cd4cecf16d
 ---> 23c266b9d5da
Successfully built 23c266b9d5da
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
a5c37a1fdfea: Preparing
801a8878b64a: Preparing
5542ba5635e7: Preparing
a32b5f7136a4: Preparing
10acb7d601b9: Preparing
9fb83b7133bf: Preparing
6b15f4685e98: Preparing
bee6f9449c51: Preparing
f46f3909e799: Preparing
2b87d5ff6454: Preparing
b5e5ebccd3e2: Preparing
65260050354e: Preparing
83d994444331: Preparing
ad38cd12a258: Preparing
4568910c2995: Preparing
26eafd96cbc2: Preparing
28a3fbb997db: Preparing
17efc79ac0fe: Preparing
0b6859e9fff1: Preparing
f46f3909e799: Waiting
11829b3be9c0: Preparing
dc8e1d8b53e9: Preparing
9d49e0bc68a4: Preparing
8e396a1aad50: Preparing
17efc79ac0fe: Waiting
0b6859e9fff1: Waiting
6b15f4685e98: Waiting
9d49e0bc68a4: Waiting
11829b3be9c0: Waiting
8e396a1aad50: Waiting
dc8e1d8b53e9: Waiting
26eafd96cbc2: Waiting
ad38cd12a258: Waiting
4568910c2995: Waiting
bee6f9449c51: Waiting
b5e5ebccd3e2: Waiting
65260050354e: Waiting
83d994444331: Waiting
2b87d5ff6454: Waiting
28a3fbb997db: Waiting
5542ba5635e7: Pushed
10acb7d601b9: Pushed
a32b5f7136a4: Pushed
a5c37a1fdfea: Pushed
801a8878b64a: Pushed
bee6f9449c51: Pushed
6b15f4685e98: Pushed
f46f3909e799: Pushed
83d994444331: Pushed
ad38cd12a258: Pushed
4568910c2995: Layer already exists
26eafd96cbc2: Layer already exists
28a3fbb997db: Layer already exists
17efc79ac0fe: Layer already exists
0b6859e9fff1: Layer already exists
b5e5ebccd3e2: Pushed
11829b3be9c0: Layer already exists
dc8e1d8b53e9: Layer already exists
8e396a1aad50: Layer already exists
9d49e0bc68a4: Layer already exists
9fb83b7133bf: Pushed
2b87d5ff6454: Pushed
65260050354e: Pushed
20230216022051: digest: sha256:cc50c988848ee7a6c918c2ca11eb935291d665dfd074b3feffabca6844fe6599 size: 5156

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 12m 47s
207 actionable tasks: 135 executed, 60 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1294

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1294/display/redirect?page=changes>

Changes:

[noreply] [Go SDK] add retries to connect with expansion service (#25237)

[noreply] SpannerIO: parameterizing partitionQuery timeout (#25236)

[noreply] Use example id as CloudPath (#25487)

[noreply] SpannerIO: Handling pg spanner.commit_timestamp (#25479)

[noreply] Fix provider to be found by AutoService (#25491)

[noreply] [Python] Added Tensorflow Model Handler  (#25368)


------------------------------------------
[...truncated 366.07 KB...]
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Invalid url for junit-quickcheck-generators-1.0: http://www.opensource.org/licenses/mit-license.php after 9 retries.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/pull_licenses_java.py",> line 58, in pull_from_url
    url_read = urlopen(Request(url, headers={
  File "/usr/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Invalid url for slf4j-api-1.7.35: http://www.opensource.org/licenses/mit-license.php after 9 retries.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/pull_licenses_java.py",> line 58, in pull_from_url
    url_read = urlopen(Request(url, headers={
  File "/usr/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Invalid url for log4j-over-slf4j-1.7.30: http://www.opensource.org/licenses/mit-license.php after 9 retries.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/pull_licenses_java.py",> line 58, in pull_from_url
    url_read = urlopen(Request(url, headers={
  File "/usr/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 563, in error
    result = self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 755, in http_error_302
    return self.parent.open(new, timeout=req.timeout)
  File "/usr/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Invalid url for slf4j-simple-1.7.30: http://www.opensource.org/licenses/mit-license.php after 9 retries.
ERROR:root:['reflectasm-1.07', 'kryo-2.21', 'junit-quickcheck-core-1.0', 'software-and-algorithms-1.0', 'slf4j-api-1.7.30', 'pcollections-2.1.2', 'slf4j-jdk14-1.7.30', 'jcl-over-slf4j-1.7.30', 'minlog-1.2', 'junit-quickcheck-generators-1.0', 'slf4j-api-1.7.35', 'log4j-over-slf4j-1.7.30', 'slf4j-simple-1.7.30']
ERROR:root:**************************************** Licenses were not able to be pulled automatically for some dependencies. Please search source code of the dependencies on the internet and add "license" and "notice" (if available) field to <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/dep_urls_java.yaml> for each missing license. Dependency List: [jcl-over-slf4j-1.7.30,junit-quickcheck-core-1.0,junit-quickcheck-generators-1.0,kryo-2.21,log4j-over-slf4j-1.7.30,minlog-1.2,pcollections-2.1.2,reflectasm-1.07,slf4j-api-1.7.30,slf4j-api-1.7.35,slf4j-jdk14-1.7.30,slf4j-simple-1.7.30,software-and-algorithms-1.0]
INFO:root:pull_licenses_java.py failed. It took 90.758201 seconds with 16 threads.
Traceback (most recent call last):
  File "<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/pull_licenses_java.py",> line 326, in <module>
    raise RuntimeError('{n} error(s) occurred.'.format(n=len(error_msg)),
RuntimeError: ('1 error(s) occurred.', ['**************************************** Licenses were not able to be pulled automatically for some dependencies. Please search source code of the dependencies on the internet and add "license" and "notice" (if available) field to <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/license_scripts/dep_urls_java.yaml> for each missing license. Dependency List: [jcl-over-slf4j-1.7.30,junit-quickcheck-core-1.0,junit-quickcheck-generators-1.0,kryo-2.21,log4j-over-slf4j-1.7.30,minlog-1.2,pcollections-2.1.2,reflectasm-1.07,slf4j-api-1.7.30,slf4j-api-1.7.35,slf4j-jdk14-1.7.30,slf4j-simple-1.7.30,software-and-algorithms-1.0]'])

> Task :sdks:java:container:pullLicenses FAILED
> Task :sdks:java:container:goPrepare UP-TO-DATE

> Task :sdks:go:container:docker

Reading state information...
The following additional packages will be installed:
  openssl
The following NEW packages will be installed:
  ca-certificates openssl
0 upgraded, 2 newly installed, 0 to remove and 1 not upgraded.
Need to get 1011 kB of archives.
After this operation, 1892 kB of additional disk space will be used.
Get:1 http://deb.debian.org/debian-security bullseye-security/main amd64 openssl amd64 1.1.1n-0+deb11u4 [853 kB]
Get:2 http://deb.debian.org/debian bullseye/main amd64 ca-certificates all 20210119 [158 kB]
debconf: delaying package configuration, since apt-utils is not installed

> Task :sdks:python:installGcpTest
Successfully installed PyJWT-2.6.0 apache-beam-2.46.0.dev0 attrs-22.2.0 azure-core-1.26.3 azure-identity-1.12.0 azure-storage-blob-12.14.1 boto3-1.26.71 botocore-1.29.71 cachetools-4.2.4 certifi-2022.12.7 cffi-1.15.1 charset-normalizer-3.0.1 cloudpickle-2.2.1 crcmod-1.7 cryptography-39.0.1 deprecation-2.1.0 dill-0.3.1.1 docker-6.0.1 docopt-0.6.2 exceptiongroup-1.1.0 execnet-1.9.0 fastavro-1.7.1 fasteners-0.18 freezegun-1.2.2 google-api-core-2.11.0 google-apitools-0.5.31 google-auth-2.16.0 google-auth-httplib2-0.1.0 google-cloud-bigquery-3.5.0 google-cloud-bigquery-storage-2.16.2 google-cloud-bigtable-1.7.3 google-cloud-core-2.3.2 google-cloud-datastore-1.15.5 google-cloud-dlp-3.11.1 google-cloud-language-1.3.2 google-cloud-pubsub-2.14.1 google-cloud-pubsublite-1.7.0 google-cloud-recommendations-ai-0.7.1 google-cloud-spanner-3.27.1 google-cloud-videointelligence-1.16.3 google-cloud-vision-3.3.1 google-crc32c-1.5.0 google-resumable-media-2.4.1 googleapis-common-protos-1.58.0 greenlet-2.0.2 grpc-google-iam-v1-0.12.6 grpcio-status-1.48.2 hdfs-2.7.0 httplib2-0.21.0 hypothesis-6.68.1 idna-3.4 iniconfig-2.0.0 isodate-0.6.1 jmespath-1.0.1 joblib-1.2.0 mock-2.0.0 msal-1.21.0 msal-extensions-1.0.0 msrest-0.7.1 oauth2client-4.1.3 oauthlib-3.2.2 objsize-0.6.1 orjson-3.8.6 overrides-6.5.0 pandas-1.5.3 parameterized-0.8.1 pbr-5.11.1 portalocker-2.7.0 proto-plus-1.22.2 psycopg2-binary-2.9.5 pyarrow-9.0.0 pyasn1-0.4.8 pyasn1-modules-0.2.8 pycparser-2.21 pydot-1.4.2 pyhamcrest-1.10.1 pymongo-3.13.0 pymysql-1.0.2 pyparsing-3.0.9 pytest-7.2.1 pytest-forked-1.6.0 pytest-timeout-2.1.0 pytest-xdist-2.5.0 python-dateutil-2.8.2 pytz-2022.7.1 pyyaml-6.0 regex-2022.10.31 requests-2.28.2 requests-oauthlib-1.3.1 requests_mock-1.10.0 rsa-4.9 s3transfer-0.6.0 scikit-learn-1.2.1 scipy-1.10.0 sortedcontainers-2.4.0 sqlalchemy-1.4.46 sqlparse-0.4.3 tenacity-5.1.5 testcontainers-3.7.1 threadpoolctl-3.1.0 tomli-2.0.1 typing-extensions-4.5.0 urllib3-1.26.14 websocket-client-1.5.1 wrapt-1.14.1 zstandard-0.19.0

> Task :sdks:java:container:goBuild
/home/jenkins/go/bin/go1.19.3 build -o ./build/target/linux_amd64/boot boot.go boot_test.go

> Task :sdks:python:container:py38:docker
Collecting pymongo==3.13.0
  Downloading pymongo-3.13.0-cp38-cp38-manylinux_2_17_x86_64.manylinux2014_x86_64.whl (526 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 526.2/526.2 KB 26.8 MB/s eta 0:00:00
Collecting PyMySQL==1.0.2
  Downloading PyMySQL-1.0.2-py3-none-any.whl (43 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 43.8/43.8 KB 4.2 MB/s eta 0:00:00
Collecting pyparsing==3.0.9
  Downloading pyparsing-3.0.9-py3-none-any.whl (98 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 98.3/98.3 KB 10.4 MB/s eta 0:00:00
Collecting pytest==7.2.1
  Downloading pytest-7.2.1-py3-none-any.whl (317 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 317.1/317.1 KB 23.5 MB/s eta 0:00:00
Collecting pytest-forked==1.4.0
  Downloading pytest_forked-1.4.0-py3-none-any.whl (4.9 kB)
Collecting pytest-timeout==2.1.0
  Downloading pytest_timeout-2.1.0-py3-none-any.whl (12 kB)
Collecting pytest-xdist==2.5.0
  Downloading pytest_xdist-2.5.0-py3-none-any.whl (41 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 41.7/41.7 KB 3.1 MB/s eta 0:00:00
Collecting python-dateutil==2.8.2
  Downloading python_dateutil-2.8.2-py2.py3-none-any.whl (247 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 247.7/247.7 KB 25.2 MB/s eta 0:00:00
Collecting python-snappy==0.6.1
  Downloading python_snappy-0.6.1-cp38-cp38-manylinux_2_12_x86_64.manylinux2010_x86_64.whl (56 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 56.1/56.1 KB 7.1 MB/s eta 0:00:00
Collecting pytz==2022.7.1
  Downloading pytz-2022.7.1-py2.py3-none-any.whl (499 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 499.4/499.4 KB 34.1 MB/s eta 0:00:00
Collecting PyYAML==6.0
  Downloading PyYAML-6.0-cp38-cp38-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_12_x86_64.manylinux2010_x86_64.whl (701 kB)
     ━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━━ 701.2/701.2 KB 42.1 MB/s eta 0:00:00

> Task :sdks:java:container:java8:copySdkHarnessLauncher
Execution optimizations have been disabled for task ':sdks:java:container:java8:copySdkHarnessLauncher' to ensure correctness due to the following reasons:
  - Gradle detected a problem with the following location: '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/build/target'.> Reason: Task ':sdks:java:container:java8:copySdkHarnessLauncher' uses this output of task ':sdks:java:container:downloadCloudProfilerAgent' without declaring an explicit or implicit dependency. This can lead to incorrect results being produced, depending on what order the tasks are executed. Please refer to https://docs.gradle.org/7.5.1/userguide/validation_problems.html#implicit_dependency for more details about this problem.
  - Gradle detected a problem with the following location: '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/java/container/build/target'.> Reason: Task ':sdks:java:container:java8:copySdkHarnessLauncher' uses this output of task ':sdks:java:container:pullLicenses' without declaring an explicit or implicit dependency. This can lead to incorrect results being produced, depending on what order the tasks are executed. Please refer to https://docs.gradle.org/7.5.1/userguide/validation_problems.html#implicit_dependency for more details about this problem.

> Task :sdks:go:container:docker
Fetched 1011 kB in 0s (3934 kB/s)
Selecting previously unselected package openssl.
(Reading database ... (Reading database ... 5%(Reading database ... 10%(Reading database ... 15%(Reading database ... 20%(Reading database ... 25%(Reading database ... 30%(Reading database ... 35%(Reading database ... 40%(Reading database ... 45%(Reading database ... 50%(Reading database ... 55%(Reading database ... 60%(Reading database ... 65%(Reading database ... 70%(Reading database ... 75%(Reading database ... 80%(Reading database ... 85%(Reading database ... 90%(Reading database ... 95%(Reading database ... 100%(Reading database ... 6661 files and directories currently installed.)
Preparing to unpack .../openssl_1.1.1n-0+deb11u4_amd64.deb ...
Unpacking openssl (1.1.1n-0+deb11u4) ...
Selecting previously unselected package ca-certificates.
Preparing to unpack .../ca-certificates_20210119_all.deb ...
Unpacking ca-certificates (20210119) ...
Setting up openssl (1.1.1n-0+deb11u4) ...
Setting up ca-certificates (20210119) ...

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 14m 47s
207 actionable tasks: 142 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1293

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1293/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215142052",
            "environmentId": "FVoTwJNuQcbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.46.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-143253",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-143253"
      }
    ]
  },
  "name": "go-testxlang_partition-978",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/15 15:20:02 Submitted job: 2023-02-15_07_20_01-3601944852730089269
2023/02/15 15:20:02 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-15_07_20_01-3601944852730089269?project=apache-beam-testing
2023/02/15 15:20:02 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-15_07_20_01-3601944852730089269
2023/02/15 15:20:02 Job state: JOB_STATE_PENDING ...
2023/02/15 15:20:32 Job still running ...
2023/02/15 15:21:02 Job still running ...
2023/02/15 15:21:32 Job still running ...
2023/02/15 15:22:02 Job still running ...
2023/02/15 15:22:32 Job still running ...
2023/02/15 15:23:02 Job still running ...
2023/02/15 15:23:32 Job still running ...
2023/02/15 15:24:02 Job still running ...
2023/02/15 15:24:32 Job still running ...
2023/02/15 15:25:02 Job still running ...
2023/02/15 15:25:32 Job still running ...
2023/02/15 15:26:02 Job still running ...
2023/02/15 15:26:32 Job still running ...
2023/02/15 15:27:03 Job still running ...
2023/02/15 15:27:33 Job still running ...
2023/02/15 15:28:03 Job still running ...
2023/02/15 15:28:33 Job still running ...
2023/02/15 15:29:03 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-15_07_20_01-3601944852730089269 failed
--- FAIL: TestXLang_Partition (582.02s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3365.472s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676471611542688926
--- FAIL: TestBigQueryIO_BasicWriteRead (4.53s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37807 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@pXrLmUYWAv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@pXrLmUYWAv"}}  windowing_strategies:{key:"w0@pXrLmUYWAv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@pXrLmUYWAv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@pXrLmUYWAv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@pXrLmUYWAv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676471611542688926\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"pXrLmUYWAv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37807 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@pXrLmUYWAv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@pXrLmUYWAv"}}  windowing_strategies:{key:"w0@pXrLmUYWAv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@pXrLmUYWAv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@pXrLmUYWAv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@pXrLmUYWAv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676471611542688926\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"pXrLmUYWAv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000231340})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000231340})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004806e0?, 0xc0004c6000?}, {0x1130842, 0x39}, {0xc0000ee180?, 0xa97d00?, 0x1?}, {0xc000654e60, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480680?, 0xc0004c6000?}, {0xc000544300, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0xe73b20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000654e60, 0xf}, {0xc000544300, 0x52}, {0xeb4b40, 0xc0003f6168})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00048b380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00048b380, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.572s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:0c82d18c18e76aa3cdded776ecb0bfc14299892ee091ec66210a564ae99ebf1d
  Associated tags:
 - 20230215-143253
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-143253
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-143253].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:0c82d18c18e76aa3cdded776ecb0bfc14299892ee091ec66210a564ae99ebf1d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215142052]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daa3347997905aabc43e19ced31cb76afe4daf9eea026bbdee49999956f0af3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215142052] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daa3347997905aabc43e19ced31cb76afe4daf9eea026bbdee49999956f0af3])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daa3347997905aabc43e19ced31cb76afe4daf9eea026bbdee49999956f0af3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7daa3347997905aabc43e19ced31cb76afe4daf9eea026bbdee49999956f0af3].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215142052]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9552edb991efaa0db5dc77899996eca316eeebd23a9a7f5af3f4a8b87b078ad8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215142052] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9552edb991efaa0db5dc77899996eca316eeebd23a9a7f5af3f4a8b87b078ad8])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9552edb991efaa0db5dc77899996eca316eeebd23a9a7f5af3f4a8b87b078ad8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9552edb991efaa0db5dc77899996eca316eeebd23a9a7f5af3f4a8b87b078ad8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 18s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/4db3dpv4lgrwc

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1292

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1292/display/redirect>

Changes:


------------------------------------------
[...truncated 537.96 KB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-083231",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215082041",
            "environmentId": "OrmRjOCbpebeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-083231"
      }
    ]
  },
  "name": "go-testxlang_partition-181",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/15 09:19:10 Submitted job: 2023-02-15_01_19_09-7094814334125246941
2023/02/15 09:19:10 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-15_01_19_09-7094814334125246941?project=apache-beam-testing
2023/02/15 09:19:10 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-15_01_19_09-7094814334125246941
2023/02/15 09:19:10 Job state: JOB_STATE_PENDING ...
2023/02/15 09:19:40 Job still running ...
2023/02/15 09:20:10 Job still running ...
2023/02/15 09:20:40 Job still running ...
2023/02/15 09:21:10 Job still running ...
2023/02/15 09:21:40 Job still running ...
2023/02/15 09:22:10 Job still running ...
2023/02/15 09:22:40 Job still running ...
2023/02/15 09:23:10 Job still running ...
2023/02/15 09:23:40 Job still running ...
2023/02/15 09:24:10 Job still running ...
2023/02/15 09:24:40 Job still running ...
2023/02/15 09:25:10 Job still running ...
2023/02/15 09:25:40 Job still running ...
2023/02/15 09:26:10 Job still running ...
2023/02/15 09:26:41 Job still running ...
2023/02/15 09:27:11 Job still running ...
2023/02/15 09:27:41 Job still running ...
2023/02/15 09:28:11 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-15_01_19_09-7094814334125246941 failed
--- FAIL: TestXLang_Partition (579.79s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3335.155s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676449989440249918
--- FAIL: TestBigQueryIO_BasicWriteRead (4.65s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38741 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@VSgZGMvdMX"  is_bounded:BOUNDED  windowing_strategy_id:"w0@VSgZGMvdMX"}}  windowing_strategies:{key:"w0@VSgZGMvdMX"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@VSgZGMvdMX"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@VSgZGMvdMX"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@VSgZGMvdMX"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676449989440249918\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"VSgZGMvdMX"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38741 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@VSgZGMvdMX"  is_bounded:BOUNDED  windowing_strategy_id:"w0@VSgZGMvdMX"}}  windowing_strategies:{key:"w0@VSgZGMvdMX"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@VSgZGMvdMX"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@VSgZGMvdMX"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@VSgZGMvdMX"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676449989440249918\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"VSgZGMvdMX"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 24 [running]:
testing.tRunner.func1.2({0xf66640, 0xc0004f69c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc0004f69c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e1860?, 0xc0000f9680?}, {0x1130842, 0x39}, {0xc0001d20c0?, 0xa97d00?, 0x1?}, {0xc000042e60, 0xf}, 0xc0001cdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e1800?, 0xc0000f9680?}, {0xc00052a360, 0x52}, {0x1?}, {0xc0001cdea8, 0x2, 0x7f07ad4bbd60?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042e60, 0xf}, {0xc00052a360, 0x52}, {0xeb4b40, 0xc0001fc170})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c0b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c0b60, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.686s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:94c4c631e7adeccad298e7f6eeb260e1f38cab25778fb3f6f64a0414110d69ed
  Associated tags:
 - 20230215-083231
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-083231
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-083231].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:94c4c631e7adeccad298e7f6eeb260e1f38cab25778fb3f6f64a0414110d69ed].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:49fef644a00aede8b346052c9055b70cac3582a650c60cdcec3d79a9e6620240]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:49fef644a00aede8b346052c9055b70cac3582a650c60cdcec3d79a9e6620240])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:49fef644a00aede8b346052c9055b70cac3582a650c60cdcec3d79a9e6620240
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:49fef644a00aede8b346052c9055b70cac3582a650c60cdcec3d79a9e6620240].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215082041]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e1b156edae63c13335d8dad3b15b27436e5a4985b2abbf26a645acdb1ad5e125]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215082041] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e1b156edae63c13335d8dad3b15b27436e5a4985b2abbf26a645acdb1ad5e125])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e1b156edae63c13335d8dad3b15b27436e5a4985b2abbf26a645acdb1ad5e125
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:e1b156edae63c13335d8dad3b15b27436e5a4985b2abbf26a645acdb1ad5e125].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 25s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1291

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1291/display/redirect?page=changes>

Changes:

[noreply] Use codecov-action@v3; v2 is no longer supported. (#25477)

[noreply] Update the title of the wordcount quickstart (#25471)


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215022047",
            "environmentId": "dzYzoicsxbbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232"
      }
    ]
  },
  "name": "go-testxlang_partition-45",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/15 03:18:36 Submitted job: 2023-02-14_19_18_35-4590682086300342593
2023/02/15 03:18:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-14_19_18_35-4590682086300342593?project=apache-beam-testing
2023/02/15 03:18:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-14_19_18_35-4590682086300342593
2023/02/15 03:18:36 Job state: JOB_STATE_PENDING ...
2023/02/15 03:19:06 Job still running ...
2023/02/15 03:19:36 Job still running ...
2023/02/15 03:20:06 Job still running ...
2023/02/15 03:20:36 Job still running ...
2023/02/15 03:21:06 Job still running ...
2023/02/15 03:21:36 Job still running ...
2023/02/15 03:22:06 Job still running ...
2023/02/15 03:22:36 Job still running ...
2023/02/15 03:23:06 Job still running ...
2023/02/15 03:23:36 Job still running ...
2023/02/15 03:24:06 Job still running ...
2023/02/15 03:24:36 Job still running ...
2023/02/15 03:25:06 Job still running ...
2023/02/15 03:25:37 Job still running ...
2023/02/15 03:26:07 Job still running ...
2023/02/15 03:26:37 Job still running ...
2023/02/15 03:27:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-14_19_18_35-4590682086300342593 failed
--- FAIL: TestXLang_Partition (550.37s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3266.146s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676428395217914452
--- FAIL: TestBigQueryIO_BasicWriteRead (5.54s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33811 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@MDyGloGSUa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@MDyGloGSUa"}}  windowing_strategies:{key:"w0@MDyGloGSUa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@MDyGloGSUa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@MDyGloGSUa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@MDyGloGSUa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676428395217914452\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"MDyGloGSUa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33811 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@MDyGloGSUa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@MDyGloGSUa"}}  windowing_strategies:{key:"w0@MDyGloGSUa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@MDyGloGSUa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@MDyGloGSUa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@MDyGloGSUa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676428395217914452\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"MDyGloGSUa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf66640, 0xc00058e480})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc00058e480})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001696e0?, 0xc0000bc910?}, {0x1130842, 0x39}, {0xc00015a0c0?, 0xa97d00?, 0x1?}, {0xc000660c50, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169680?, 0xc0000bc910?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe73b20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000660c50, 0xf}, {0xc00004c4e0, 0x52}, {0xeb4b40, 0xc0003f30e8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000caea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000caea0, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.577s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.042s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.057s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d0af5e41666f6df6803bdc1ceb083c941d8cc366200673cfeb4074a9753b447d
Deleted: sha256:61b2ef927f2126ecac1409c448d31cf1752d1e0ca93a7452642a17cfe1df1fc7
Deleted: sha256:51239642af23602b3b540976524c839fe652d60588772b224a0a85b701e779e5
Deleted: sha256:3d97cded41823cdfab8581da19da1ffcbc1cc243ffd912b85342a73cf7395dbc
Deleted: sha256:21a7193d30a51c0cc62aaa7c15b07b410cc2c838f426e24b969115396db85e4a
Deleted: sha256:e09e63a7c710b6048dab4f794bec166a1c47125847737bd7e89a22ae973e6322
Deleted: sha256:79d5db9391b337cbba4821250ad66a85e7daa1e7eed050a81d0a27eaa9862a5d
Deleted: sha256:b6b1c787543f04823158e0ca116ddcda03131275aad0be1a7288bd922060b822
Deleted: sha256:6515b2dbf6ef868ba86dbaab8c1475cc1f31fe53a4b1bd534fdc0377579320de
Deleted: sha256:2cc2419d304ea2228519461460bb1b0523bf52ce02265da2b71092e856995cba
Deleted: sha256:032983f0ee310a93f798a00a49d248f8594f91c006d6d1729b47658691f19a05
Deleted: sha256:762504769ab2bddf0953bdc5f55aef62bd11847ad10924ef33c2f3c4c56caac1
Deleted: sha256:ba77490ba0adde3128222a8725bc7ed09313cdfad5b4a5e3046d03457679b4c1
Deleted: sha256:3bb54495bf333e4c7a92ceaf7c6db907c34a5c20d45e123dfbc85370b71a0fb1
Deleted: sha256:bd42f9cc96e9820f5cd95a86deecfdb4353f8262cce27a94c10ba29e8859e7c3
Deleted: sha256:dbc6bb43cb4526576f69e276734fc30051f22f344982bd62756c3bf8fe1699ff
Deleted: sha256:5fec9de0acc083896e3638a0cc2156de262559a8c92182ba5337a6aa73989952
Deleted: sha256:b7a62fbe4d61e011ed0cd9debbe3df9630338183e1dc8d0fc5ac56687981bc22
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d0af5e41666f6df6803bdc1ceb083c941d8cc366200673cfeb4074a9753b447d
  Associated tags:
 - 20230215-023232
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230215-023232].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d0af5e41666f6df6803bdc1ceb083c941d8cc366200673cfeb4074a9753b447d].
$ rm -rf /tmp/tmp.oU7JBABVeG
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215022047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230215022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3395b18345baae224189ddc5dfa08701bbecf039e50dab3ff9e2c28e0ac71793].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215022047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230215022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ceee645a6d46c49741c21ec7ad731d1f36a6d6ffe26ab75868bf11f2fcd26127].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3365443.
Stopping expansion service pid: 3365444.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 17s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1290

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1290/display/redirect?page=changes>

Changes:

[noreply] Fix pulling licenses (#25456)

[noreply] Update grafana dashboard to handle name change for

[noreply] Test loading URLs (#25034)

[noreply] Fixing issue with ErrorCapture transform where pipeline issues are

[noreply] [24464] Finalize FileWriteSchemaTransformProvider (#25420)


------------------------------------------
[...truncated 553.37 KB...]
cachetools==4.2.4
certifi==2022.12.7
cffi==1.15.1
charset-normalizer==3.0.1
click==8.1.3
cloudpickle==2.2.1
crcmod==1.7
cryptography==39.0.0
Cython==0.29.33
deprecation==2.1.0
dill==0.3.1.1
docker==6.0.1
docopt==0.6.2
exceptiongroup==1.1.0
execnet==1.9.0
fastavro==1.7.0
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.74.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.4.2
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.0
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.0
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.1
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.65.0
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.3.1
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container 96d43fc75355
 ---> 4068f08fe5a2
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 24df00b1afd1
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> ab84399f3ee2
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> fc827a70dfed
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 24dc9fe999b0
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in a4d86b9cbb63
Removing intermediate container a4d86b9cbb63
 ---> 8e86abac9957
Step 22/32 : FROM beam as third_party_licenses
 ---> 8e86abac9957
Step 23/32 : ARG pull_licenses
 ---> Running in b6e3e46bb711
Removing intermediate container b6e3e46bb711
 ---> 181e3016af3e
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 13e5113ef595
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> dbfd5191be03
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in f4e097e5a79c
Removing intermediate container f4e097e5a79c
 ---> 908a1d219cef
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 3907ee722ee7
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in f2d2713beaaf
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=f9883c9d48d10a33ff08b856c9e7b7d66944949faf8a94a9ba6fa6d4e59f7283
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container f2d2713beaaf
 ---> 1eba0a30f072
Step 29/32 : FROM beam
 ---> 8e86abac9957
Step 30/32 : ARG pull_licenses
 ---> Running in 0fb704e3a8b1
Removing intermediate container 0fb704e3a8b1
 ---> 54dc53dc94e4
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> cc346d077de5
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 72effd041b3f
Removing intermediate container 72effd041b3f
 ---> 864f1e0a0630
Successfully built 864f1e0a0630
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:fn-execution:compileJava'.
> Failed to load cache entry fcbcfdb6376f02ec6c2bef5bee826e36 for task ':sdks:java:fn-execution:compileJava': Could not load from local cache: Timeout waiting to lock Build cache (/home/jenkins/.gradle/caches/build-cache-1). It is currently in use by another Gradle instance.
  Owner PID: 3909170
  Our PID: 3946712
  Owner Operation: 
  Our operation: 
  Lock file: /home/jenkins/.gradle/caches/build-cache-1/build-cache-1.lock

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 15m 39s
142 actionable tasks: 99 executed, 31 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1289

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1289/display/redirect>

Changes:


------------------------------------------
[...truncated 613.04 KB...]
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.3.1
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container 846dce37a58c
 ---> dd92e3c08cd6
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> e6da6cde0cff
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 0af2550ad876
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 4bacf076c0b3
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 698eb29dfbda
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 0bdac3d462d9
Removing intermediate container 0bdac3d462d9
 ---> 864963d1ae96
Step 22/32 : FROM beam as third_party_licenses
 ---> 864963d1ae96
Step 23/32 : ARG pull_licenses
 ---> Running in f3e249bfd869
Removing intermediate container f3e249bfd869
 ---> 482f12c132d2
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 297cb3dbd8f5
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> ec5fba3be786
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 6b994ba1c1d0
Removing intermediate container 6b994ba1c1d0
 ---> 75fe29041f49
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 4bde355b1c76
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in f13d7357c664
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=7b90a1133ccff8de9b8fc2cf2134867d9905bb0bc578cb9c6a027286f3f5842c
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container f13d7357c664
 ---> 128bc4f659b8
Step 29/32 : FROM beam
 ---> 864963d1ae96
Step 30/32 : ARG pull_licenses
 ---> Running in 72706a1f21bc
Removing intermediate container 72706a1f21bc
 ---> 41646bf6d4f5
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> e6f84a4466d2
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 87c068bec200
Removing intermediate container 87c068bec200
 ---> ac6d1bdb6203
Successfully built ac6d1bdb6203
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
e149493311d9: Preparing
9edb621b940f: Preparing
841ea24ba320: Preparing
264160c40a22: Preparing
1a4ef60d61cc: Preparing
68e963613d19: Preparing
803d7982c77c: Preparing
736931364605: Preparing
b7ebdac47155: Preparing
0489b87f5576: Preparing
42c2cfb09db6: Preparing
957492ee35ae: Preparing
296dc1e5b1ce: Preparing
5c561952e34a: Preparing
4568910c2995: Preparing
26eafd96cbc2: Preparing
28a3fbb997db: Preparing
17efc79ac0fe: Preparing
0b6859e9fff1: Preparing
11829b3be9c0: Preparing
dc8e1d8b53e9: Preparing
9d49e0bc68a4: Preparing
803d7982c77c: Waiting
8e396a1aad50: Preparing
b7ebdac47155: Waiting
736931364605: Waiting
0489b87f5576: Waiting
28a3fbb997db: Waiting
dc8e1d8b53e9: Waiting
42c2cfb09db6: Waiting
0b6859e9fff1: Waiting
9d49e0bc68a4: Waiting
17efc79ac0fe: Waiting
957492ee35ae: Waiting
4568910c2995: Waiting
26eafd96cbc2: Waiting
5c561952e34a: Waiting
e149493311d9: Pushed
264160c40a22: Pushed
1a4ef60d61cc: Pushed
841ea24ba320: Pushed
9edb621b940f: Pushed
736931364605: Pushed
b7ebdac47155: Pushed
803d7982c77c: Pushed
296dc1e5b1ce: Pushed
5c561952e34a: Pushed
4568910c2995: Layer already exists
26eafd96cbc2: Layer already exists
28a3fbb997db: Layer already exists
17efc79ac0fe: Layer already exists
0b6859e9fff1: Layer already exists
42c2cfb09db6: Pushed
11829b3be9c0: Layer already exists
dc8e1d8b53e9: Layer already exists
9d49e0bc68a4: Layer already exists
8e396a1aad50: Layer already exists
68e963613d19: Pushed
0489b87f5576: Pushed
957492ee35ae: Pushed
20230214142048: digest: sha256:2fa02b981b219f83ad9d6b406e73866fe2668b98a8e23bdbab10bb4e6d028868 size: 5156

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 11m 44s
207 actionable tasks: 134 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1288

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1288/display/redirect?page=changes>

Changes:

[noreply] Remove python 3.6 references (#25445)


------------------------------------------
[...truncated 614.50 KB...]
apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
astunparse==1.6.3
attrs==22.2.0
beautifulsoup4==4.11.1
bs4==0.0.1
cachetools==4.2.4
certifi==2022.12.7
cffi==1.15.1
charset-normalizer==3.0.1
click==8.1.3
cloudpickle==2.2.1
crcmod==1.7
cryptography==39.0.0
Cython==0.29.33
deprecation==2.1.0
dill==0.3.1.1
docker==6.0.1
docopt==0.6.2
exceptiongroup==1.1.0
execnet==1.9.0
fastavro==1.7.0
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.74.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.4.2
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.0
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.0
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.1
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.65.0
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.2.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container f6f7d229fb01
 ---> 5322c11f10a8
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 40ef1e74f445
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 12ce6a81fbba
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> d5079cff5fb3
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> cea8fef22eef
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 49c91a0daddb
Removing intermediate container 49c91a0daddb
 ---> 41513816fd4f
Step 22/32 : FROM beam as third_party_licenses
 ---> 41513816fd4f
Step 23/32 : ARG pull_licenses
 ---> Running in c9775bac46a3
Removing intermediate container c9775bac46a3
 ---> 7adcab21df32
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 0e1d30466c3c
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 09878f1f17d5
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 1b161d8bca70
Removing intermediate container 1b161d8bca70
 ---> 96f3c504c94d
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> f515d8ad1e02
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 63fd7f5a4a1c
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=0234ad1f9823f41302e1494cbcd87c7f49ea672bee84287bd44673248c27cd1f
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 63fd7f5a4a1c
 ---> 6ba4b10eb14f
Step 29/32 : FROM beam
 ---> 41513816fd4f
Step 30/32 : ARG pull_licenses
 ---> Running in 11572109f525
Removing intermediate container 11572109f525
 ---> 5371726b451e
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 6c1b038b1c3f
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in f3cbd9b92f4c
Removing intermediate container f3cbd9b92f4c
 ---> 95077d78bdd7
Successfully built 95077d78bdd7
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 12m 59s
207 actionable tasks: 134 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1287

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1287/display/redirect?page=changes>

Changes:

[xqhu] Ignore flags for beam_sql magic

[xqhu] Raise the error when some functions are misused

[xqhu] change how to import

[noreply] Validate that GBK coders are always set correctly. (#25394)

[noreply] Fix tox error running hdfsIntegrationTest (#25446)

[noreply] Adding support for DLQ for ZetaSQL (#25426)


------------------------------------------
[...truncated 619.45 KB...]
apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
astunparse==1.6.3
attrs==22.2.0
beautifulsoup4==4.11.1
bs4==0.0.1
cachetools==4.2.4
certifi==2022.12.7
cffi==1.15.1
charset-normalizer==3.0.1
click==8.1.3
cloudpickle==2.2.1
crcmod==1.7
cryptography==39.0.0
Cython==0.29.33
deprecation==2.1.0
dill==0.3.1.1
docker==6.0.1
docopt==0.6.2
exceptiongroup==1.1.0
execnet==1.9.0
fastavro==1.7.0
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.74.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.4.2
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.0
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.0
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.1
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.65.0
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.2.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container 20e87cea4456
 ---> f4d901c5259c
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 567ac4c75539
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 961715152b8c
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 7d1151441e61
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 03a14d709199
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 20f140410f1d
Removing intermediate container 20f140410f1d
 ---> 39567f638dd8
Step 22/32 : FROM beam as third_party_licenses
 ---> 39567f638dd8
Step 23/32 : ARG pull_licenses
 ---> Running in dfd74a698522
Removing intermediate container dfd74a698522
 ---> cd774664b281
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 8eaf9cf1c684
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> e073309ae5d9
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 990d98c6c89c
Removing intermediate container 990d98c6c89c
 ---> 61b9d3d1d52e
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 481b8cb68570
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 30d6797d218a
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=4b5721e6789f02b08a085d1c24e8290972086a1d050b38e8a366dd50e68e249e
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 30d6797d218a
 ---> 13b42e754cfc
Step 29/32 : FROM beam
 ---> 39567f638dd8
Step 30/32 : ARG pull_licenses
 ---> Running in 9c5d27cfa5b8
Removing intermediate container 9c5d27cfa5b8
 ---> 121a14a6fbb6
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 89428803034f
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in e7a9bdbef099
Removing intermediate container e7a9bdbef099
 ---> e35b882f69a5
Successfully built e35b882f69a5
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 12m 25s
207 actionable tasks: 148 executed, 47 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1286

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1286/display/redirect?page=changes>

Changes:

[noreply] (#25316) Enable LZMA compression in Python SDK I/O (#25317)

[noreply] Add WatchFilePattern  (#25393)

[noreply] Support gauge metrics in portable mode (#25396)


------------------------------------------
[...truncated 629.31 KB...]
apache-beam @ file:///opt/apache/beam/tars/apache-beam.tar.gz
astunparse==1.6.3
attrs==22.2.0
beautifulsoup4==4.11.1
bs4==0.0.1
cachetools==4.2.4
certifi==2022.12.7
cffi==1.15.1
charset-normalizer==3.0.1
click==8.1.3
cloudpickle==2.2.1
crcmod==1.7
cryptography==39.0.0
Cython==0.29.33
deprecation==2.1.0
dill==0.3.1.1
docker==6.0.1
docopt==0.6.2
exceptiongroup==1.1.0
execnet==1.9.0
fastavro==1.7.0
fasteners==0.18
flatbuffers==23.1.21
freezegun==1.2.2
future==0.18.3
gast==0.4.0
google-api-core==2.11.0
google-api-python-client==2.74.0
google-apitools==0.5.31
google-auth==2.16.0
google-auth-httplib2==0.1.0
google-auth-oauthlib==0.4.6
google-cloud-bigquery==3.4.2
google-cloud-bigquery-storage==2.16.2
google-cloud-bigtable==1.7.3
google-cloud-core==2.3.2
google-cloud-datastore==1.15.5
google-cloud-dlp==3.11.1
google-cloud-language==1.3.2
google-cloud-profiler==3.1.0
google-cloud-pubsub==2.14.0
google-cloud-pubsublite==1.6.0
google-cloud-recommendations-ai==0.7.1
google-cloud-spanner==3.27.0
google-cloud-videointelligence==1.16.3
google-cloud-vision==3.3.1
google-crc32c==1.5.0
google-pasta==0.2.0
google-resumable-media==2.4.1
googleapis-common-protos==1.58.0
greenlet==2.0.1
grpc-google-iam-v1==0.12.6
grpcio==1.51.1
grpcio-status==1.48.2
guppy3==3.1.2
h5py==3.8.0
hdfs==2.7.0
httplib2==0.21.0
hypothesis==6.65.0
idna==3.4
importlib-metadata==6.0.0
iniconfig==2.0.0
joblib==1.2.0
keras==2.11.0
libclang==15.0.6.1
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.2.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container d1c8090a8d71
 ---> f95305d10492
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 1ee0ab76b20a
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 66ff9a9c5535
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 07d133aa6ac7
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 503b455160f2
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 15f3a83ab71e
Removing intermediate container 15f3a83ab71e
 ---> 523d826f2b20
Step 22/32 : FROM beam as third_party_licenses
 ---> 523d826f2b20
Step 23/32 : ARG pull_licenses
 ---> Running in 9c9f57d7954b
Removing intermediate container 9c9f57d7954b
 ---> 741c83f6eeca
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 2292d12d650e
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 905902de1bc8
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 6e74e877b829
Removing intermediate container 6e74e877b829
 ---> 4a083ea65ce0
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 7a5396784171
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 95eda2488dce
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=c8021b6dfbd22755179ba5c282cb91ebce8b2474693bbe253281c968a7aba234
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
Skip pulling license for  bs4
INFO:root:Successfully pulled licenses for 136 dependencies
Removing intermediate container 95eda2488dce
 ---> 5f854ecbcff0
Step 29/32 : FROM beam
 ---> 523d826f2b20
Step 30/32 : ARG pull_licenses
 ---> Running in dc7d368b09ae
Removing intermediate container dc7d368b09ae
 ---> 1dcd9f62a81c
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 3f8e5fc88326
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 48186af1aa3e
Removing intermediate container 48186af1aa3e
 ---> 4ab9a66969a3
Successfully built 4ab9a66969a3
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker


FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 13m 46s
207 actionable tasks: 147 executed, 48 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1285

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1285/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213142051",
            "environmentId": "VAwmustFFFbeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.46.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-143955",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-143955"
      }
    ]
  },
  "name": "go-testxlang_partition-863",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/13 15:25:58 Submitted job: 2023-02-13_07_25_57-7077623958822872128
2023/02/13 15:25:58 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-13_07_25_57-7077623958822872128?project=apache-beam-testing
2023/02/13 15:25:58 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-13_07_25_57-7077623958822872128
2023/02/13 15:25:58 Job state: JOB_STATE_PENDING ...
2023/02/13 15:26:28 Job still running ...
2023/02/13 15:26:58 Job still running ...
2023/02/13 15:27:28 Job still running ...
2023/02/13 15:27:58 Job still running ...
2023/02/13 15:28:28 Job still running ...
2023/02/13 15:28:58 Job still running ...
2023/02/13 15:29:28 Job still running ...
2023/02/13 15:29:59 Job still running ...
2023/02/13 15:30:29 Job still running ...
2023/02/13 15:30:59 Job still running ...
2023/02/13 15:31:29 Job still running ...
2023/02/13 15:31:59 Job still running ...
2023/02/13 15:32:29 Job still running ...
2023/02/13 15:32:59 Job still running ...
2023/02/13 15:33:29 Job still running ...
2023/02/13 15:33:59 Job still running ...
2023/02/13 15:34:29 Job still running ...
2023/02/13 15:34:59 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-13_07_25_57-7077623958822872128 failed
--- FAIL: TestXLang_Partition (582.90s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3285.352s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676299252165403484
--- FAIL: TestBigQueryIO_BasicWriteRead (6.64s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38359 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@iYUWrMfLLc"  is_bounded:BOUNDED  windowing_strategy_id:"w0@iYUWrMfLLc"}}  windowing_strategies:{key:"w0@iYUWrMfLLc"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@iYUWrMfLLc"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@iYUWrMfLLc"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@iYUWrMfLLc"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676299252165403484\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"iYUWrMfLLc"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38359 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@iYUWrMfLLc"  is_bounded:BOUNDED  windowing_strategy_id:"w0@iYUWrMfLLc"}}  windowing_strategies:{key:"w0@iYUWrMfLLc"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@iYUWrMfLLc"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@iYUWrMfLLc"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@iYUWrMfLLc"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676299252165403484\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"iYUWrMfLLc"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000112f00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000112f00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000489260?, 0xc0004bdbd0?}, {0x1130842, 0x39}, {0xc0000f6180?, 0xa97d00?, 0x1?}, {0xc00048d290, 0xf}, 0xc00016bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000489200?, 0xc0004bdbd0?}, {0xc00004cb40, 0x52}, {0x1?}, {0xc00016bea8, 0x2, 0x7fb9eb35f448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048d290, 0xf}, {0xc00004cb40, 0x52}, {0xeb4b40, 0xc000042f60})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000495380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000495380, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.679s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.045s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.058s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1eef8e1225f2205c56cfd1ae9e4a8ce3b7f2ad947617a9d523fb2b4f76e8a867
  Associated tags:
 - 20230213-143955
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-143955
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-143955].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1eef8e1225f2205c56cfd1ae9e4a8ce3b7f2ad947617a9d523fb2b4f76e8a867].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213142051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:08cf1e353d8eddc24f6e4003f05e72c0d98e5bb7c642cea34bdf0bd64048a984]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213142051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:08cf1e353d8eddc24f6e4003f05e72c0d98e5bb7c642cea34bdf0bd64048a984])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:08cf1e353d8eddc24f6e4003f05e72c0d98e5bb7c642cea34bdf0bd64048a984
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:08cf1e353d8eddc24f6e4003f05e72c0d98e5bb7c642cea34bdf0bd64048a984].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213142051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86422a3f8fb519bcb11cbc6be082c0e15dd7064bac7a8d9408b835dac9bbc407]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213142051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86422a3f8fb519bcb11cbc6be082c0e15dd7064bac7a8d9408b835dac9bbc407])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86422a3f8fb519bcb11cbc6be082c0e15dd7064bac7a8d9408b835dac9bbc407
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:86422a3f8fb519bcb11cbc6be082c0e15dd7064bac7a8d9408b835dac9bbc407].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 15m 15s
216 actionable tasks: 147 executed, 57 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/4fjh3p6e3vjwu

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1284

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1284/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213082050",
            "environmentId": "zDlIKaaCKibeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243"
      }
    ]
  },
  "name": "go-testxlang_partition-880",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/13 09:18:42 Submitted job: 2023-02-13_01_18_42-14139282410806840359
2023/02/13 09:18:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-13_01_18_42-14139282410806840359?project=apache-beam-testing
2023/02/13 09:18:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-13_01_18_42-14139282410806840359
2023/02/13 09:18:42 Job state: JOB_STATE_PENDING ...
2023/02/13 09:19:12 Job still running ...
2023/02/13 09:19:42 Job still running ...
2023/02/13 09:20:12 Job still running ...
2023/02/13 09:20:43 Job still running ...
2023/02/13 09:21:13 Job still running ...
2023/02/13 09:21:43 Job still running ...
2023/02/13 09:22:13 Job still running ...
2023/02/13 09:22:43 Job still running ...
2023/02/13 09:23:13 Job still running ...
2023/02/13 09:23:43 Job still running ...
2023/02/13 09:24:13 Job still running ...
2023/02/13 09:24:43 Job still running ...
2023/02/13 09:25:13 Job still running ...
2023/02/13 09:25:43 Job still running ...
2023/02/13 09:26:13 Job still running ...
2023/02/13 09:26:43 Job still running ...
2023/02/13 09:27:13 Job still running ...
2023/02/13 09:27:43 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-13_01_18_42-14139282410806840359 failed
--- FAIL: TestXLang_Partition (579.70s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3297.935s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676277199189034569
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43115 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BsjWRudNiM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BsjWRudNiM"}}  windowing_strategies:{key:"w0@BsjWRudNiM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BsjWRudNiM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BsjWRudNiM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BsjWRudNiM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676277199189034569\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BsjWRudNiM"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43115 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@BsjWRudNiM"  is_bounded:BOUNDED  windowing_strategy_id:"w0@BsjWRudNiM"}}  windowing_strategies:{key:"w0@BsjWRudNiM"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@BsjWRudNiM"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@BsjWRudNiM"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@BsjWRudNiM"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676277199189034569\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"BsjWRudNiM"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000536440})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000536440})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480b00?, 0xc0001179f0?}, {0x1130842, 0x39}, {0xc00015e0c0?, 0xa97d00?, 0x1?}, {0xc00049ec80, 0xf}, 0xc0002e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480aa0?, 0xc0001179f0?}, {0xc00047c360, 0x52}, {0x1?}, {0xc0002e9ea8, 0x2, 0x7f48da8d0da0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00049ec80, 0xf}, {0xc00047c360, 0x52}, {0xeb4b40, 0xc00049ff90})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000268d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000268d00, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.359s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.042s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a22859908e8f9d0331a93f7e75ebe4291276c0050dc9bf5c1453acc08abbc4c1
Deleted: sha256:026ca70b2ec548217d3b98a964021bba253c5d15dcd58a83d318e314b68526de
Deleted: sha256:26559936df15db093296d3493b9a1944364bbf8af45a3b7ebd25d45f29bf0251
Deleted: sha256:b7906820b0543abfab6a1bd68b04702b320e18fa26c7bc51a77ac763d8847586
Deleted: sha256:e1449370ecb70e2d4a4b6300318da482a2f15056508ea933bb8080260fa88444
Deleted: sha256:812591f264c560c8761d84d521ff1b2aa0965391eda38847feb722c456fe95db
Deleted: sha256:5667ad1f1a5593637a4716c435433e21be6a7c677077869d061501c331ad1caa
Deleted: sha256:14a6801a6e316460abe83e79a41dc6b494e28eb1b9d130722aed580ff6cc5c00
Deleted: sha256:8e3973227d89af7b8637173668328f191439d9537bb2797ed669b150ff39e0ce
Deleted: sha256:36efb23c5ab8647502ea537297f296452727528b2cfcf3acac2afe03c89e7b44
Deleted: sha256:d56fd259e78b80f7837a2a52abd35601e94f18e42c0e701b1c0107b74b5336fe
Deleted: sha256:d1255396173561fd952f93806c4ae9f7f4a8ddde23678026b0450ff08fc614ff
Deleted: sha256:1de2349f0bc9f3afa9b2bf1947da521c0f7f31c8fd307cf1877b9ad83b01c3a6
Deleted: sha256:48ca7d3caa03c52c9886b5852f87876433fb38280e34982357998e1ba1136b90
Deleted: sha256:47e591c320d024e82928e6617265bed119b9f6e161d3b49c8172bb809bf3fba4
Deleted: sha256:eb8f90d935be4e573cd4399188adcf6b9bd4c51d4ca1540ef24068e12b9205f5
Deleted: sha256:41ee0ffdce61f5f62396ddc6f650bf856dd3ff070b3b8e1244a02e4cd9a559c5
Deleted: sha256:12aa6e15af225e15b4efd02696ac9d120285888bf68f7adc9cdc5199a9387cd1
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a22859908e8f9d0331a93f7e75ebe4291276c0050dc9bf5c1453acc08abbc4c1
  Associated tags:
 - 20230213-083243
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-083243].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a22859908e8f9d0331a93f7e75ebe4291276c0050dc9bf5c1453acc08abbc4c1].
$ rm -rf /tmp/tmp.t4xwbeYjuI
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:920fe69b994bb8ed2b8e5da734a093dfb49c27a59469b59c63449c9fe14766ac].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4026e28660d0d87464c2154f405c5c35b5f9006e7e0a08032a2531a5ed0a2ddb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3347811.
Stopping expansion service pid: 3347812.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 52s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1283

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1283/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-023224",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213022047",
            "environmentId": "MtBuDzYvMobeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-023224"
      }
    ]
  },
  "name": "go-testxlang_partition-390",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/13 03:17:13 Submitted job: 2023-02-12_19_17_13-16231068817925507138
2023/02/13 03:17:13 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-12_19_17_13-16231068817925507138?project=apache-beam-testing
2023/02/13 03:17:13 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-12_19_17_13-16231068817925507138
2023/02/13 03:17:13 Job state: JOB_STATE_PENDING ...
2023/02/13 03:17:44 Job still running ...
2023/02/13 03:18:14 Job still running ...
2023/02/13 03:18:44 Job still running ...
2023/02/13 03:19:14 Job still running ...
2023/02/13 03:19:44 Job still running ...
2023/02/13 03:20:14 Job still running ...
2023/02/13 03:20:44 Job still running ...
2023/02/13 03:21:14 Job still running ...
2023/02/13 03:21:44 Job still running ...
2023/02/13 03:22:14 Job still running ...
2023/02/13 03:22:44 Job still running ...
2023/02/13 03:23:14 Job still running ...
2023/02/13 03:23:44 Job still running ...
2023/02/13 03:24:14 Job still running ...
2023/02/13 03:24:44 Job still running ...
2023/02/13 03:25:14 Job still running ...
2023/02/13 03:25:44 Job still running ...
2023/02/13 03:26:14 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-12_19_17_13-16231068817925507138 failed
--- FAIL: TestXLang_Partition (579.08s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3227.476s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676255580625915795
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32891 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@oNXcDOzxMw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@oNXcDOzxMw"}}  windowing_strategies:{key:"w0@oNXcDOzxMw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@oNXcDOzxMw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@oNXcDOzxMw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@oNXcDOzxMw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676255580625915795\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"oNXcDOzxMw"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:32891 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@oNXcDOzxMw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@oNXcDOzxMw"}}  windowing_strategies:{key:"w0@oNXcDOzxMw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@oNXcDOzxMw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@oNXcDOzxMw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@oNXcDOzxMw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676255580625915795\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"oNXcDOzxMw"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 41 [running]:
testing.tRunner.func1.2({0xf66640, 0xc0004fb800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc0004fb800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00001a1a0?, 0xc000202000?}, {0x1130842, 0x39}, {0xc0000ee180?, 0xa97d00?, 0x1?}, {0xc000043dd0, 0xf}, 0xc00013bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00001a140?, 0xc000202000?}, {0xc0004c83c0, 0x52}, {0x1?}, {0xc00013bea8, 0x2, 0xe73b20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043dd0, 0xf}, {0xc0004c83c0, 0x52}, {0xeb4b40, 0xc00001c058})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000495520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000495520, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.292s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.040s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5241aea19d11523ab61e9cd577455b07a26becc83e83e3d5902e8c22e3c71549
  Associated tags:
 - 20230213-023224
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-023224
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230213-023224].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5241aea19d11523ab61e9cd577455b07a26becc83e83e3d5902e8c22e3c71549].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38bc9c4dfb8f240976222a913667b5a7b1dc0f9ae6a540a28c2b158aa53b1cbd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230213022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38bc9c4dfb8f240976222a913667b5a7b1dc0f9ae6a540a28c2b158aa53b1cbd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38bc9c4dfb8f240976222a913667b5a7b1dc0f9ae6a540a28c2b158aa53b1cbd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:38bc9c4dfb8f240976222a913667b5a7b1dc0f9ae6a540a28c2b158aa53b1cbd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c47ec2aa271d475e0daffb7f52646de870e38c443f0dc3590b49b8bf237df38c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230213022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c47ec2aa271d475e0daffb7f52646de870e38c443f0dc3590b49b8bf237df38c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c47ec2aa271d475e0daffb7f52646de870e38c443f0dc3590b49b8bf237df38c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c47ec2aa271d475e0daffb7f52646de870e38c443f0dc3590b49b8bf237df38c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 22s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/7jkuoeqxuq5gw

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1282

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1282/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-203322",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212202049",
            "environmentId": "JCKfXcZIoDbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-203322"
      }
    ]
  },
  "name": "go-testxlang_partition-127",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/12 21:18:40 Submitted job: 2023-02-12_13_18_40-12786093279425241786
2023/02/12 21:18:40 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-12_13_18_40-12786093279425241786?project=apache-beam-testing
2023/02/12 21:18:40 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-12_13_18_40-12786093279425241786
2023/02/12 21:18:40 Job state: JOB_STATE_PENDING ...
2023/02/12 21:19:10 Job still running ...
2023/02/12 21:19:40 Job still running ...
2023/02/12 21:20:10 Job still running ...
2023/02/12 21:20:41 Job still running ...
2023/02/12 21:21:11 Job still running ...
2023/02/12 21:21:41 Job still running ...
2023/02/12 21:22:11 Job still running ...
2023/02/12 21:22:41 Job still running ...
2023/02/12 21:23:11 Job still running ...
2023/02/12 21:23:41 Job still running ...
2023/02/12 21:24:11 Job still running ...
2023/02/12 21:24:41 Job still running ...
2023/02/12 21:25:11 Job still running ...
2023/02/12 21:25:41 Job still running ...
2023/02/12 21:26:11 Job still running ...
2023/02/12 21:26:41 Job still running ...
2023/02/12 21:27:11 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-12_13_18_40-12786093279425241786 failed
--- FAIL: TestXLang_Partition (549.36s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3226.998s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676234038313512720
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43979 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qoPiPfbyTK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qoPiPfbyTK"}}  windowing_strategies:{key:"w0@qoPiPfbyTK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qoPiPfbyTK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qoPiPfbyTK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qoPiPfbyTK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676234038313512720\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qoPiPfbyTK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43979 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qoPiPfbyTK"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qoPiPfbyTK"}}  windowing_strategies:{key:"w0@qoPiPfbyTK"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qoPiPfbyTK"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qoPiPfbyTK"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qoPiPfbyTK"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676234038313512720\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qoPiPfbyTK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf66640, 0xc00045edc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc00045edc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001245c0?, 0xc000140000?}, {0x1130842, 0x39}, {0xc0000ee180?, 0xa97d00?, 0x1?}, {0xc00011aca0, 0xf}, 0xc000031d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000124560?, 0xc000140000?}, {0xc0004e4300, 0x52}, {0x1?}, {0xc000031ea8, 0x2, 0x7fc449a1c448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011aca0, 0xf}, {0xc0004e4300, 0x52}, {0xeb4b40, 0xc000042470})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.423s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d1bc81a6a0ff62e527a8d4ae42818327f630f1b6a2dc0feb39cf09a83dd069b7
  Associated tags:
 - 20230212-203322
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-203322
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-203322].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d1bc81a6a0ff62e527a8d4ae42818327f630f1b6a2dc0feb39cf09a83dd069b7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212202049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c48c6b60b59559312deb363693e5af7079d2d05def77d39dfdfaae39531a6d86]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212202049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c48c6b60b59559312deb363693e5af7079d2d05def77d39dfdfaae39531a6d86])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c48c6b60b59559312deb363693e5af7079d2d05def77d39dfdfaae39531a6d86
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c48c6b60b59559312deb363693e5af7079d2d05def77d39dfdfaae39531a6d86].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212202049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4b5a90f8ca96a0a22d27d6481a14975f3d8a5de7baaa44a0751ff9e66d7670f5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212202049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4b5a90f8ca96a0a22d27d6481a14975f3d8a5de7baaa44a0751ff9e66d7670f5])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4b5a90f8ca96a0a22d27d6481a14975f3d8a5de7baaa44a0751ff9e66d7670f5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4b5a90f8ca96a0a22d27d6481a14975f3d8a5de7baaa44a0751ff9e66d7670f5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 18s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1281

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1281/display/redirect>

Changes:


------------------------------------------
[...truncated 1.03 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212142046",
            "environmentId": "BMVbyucpZQbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221"
      }
    ]
  },
  "name": "go-testxlang_partition-567",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/12 15:18:16 Submitted job: 2023-02-12_07_18_15-7006645845654708745
2023/02/12 15:18:16 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-12_07_18_15-7006645845654708745?project=apache-beam-testing
2023/02/12 15:18:16 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-12_07_18_15-7006645845654708745
2023/02/12 15:18:16 Job state: JOB_STATE_PENDING ...
2023/02/12 15:18:46 Job still running ...
2023/02/12 15:19:16 Job still running ...
2023/02/12 15:19:46 Job still running ...
2023/02/12 15:20:16 Job still running ...
2023/02/12 15:20:46 Job still running ...
2023/02/12 15:21:16 Job still running ...
2023/02/12 15:21:46 Job still running ...
2023/02/12 15:22:16 Job still running ...
2023/02/12 15:22:46 Job still running ...
2023/02/12 15:23:16 Job still running ...
2023/02/12 15:23:47 Job still running ...
2023/02/12 15:24:17 Job still running ...
2023/02/12 15:24:47 Job still running ...
2023/02/12 15:25:17 Job still running ...
2023/02/12 15:25:47 Job still running ...
2023/02/12 15:26:17 Job still running ...
2023/02/12 15:26:47 Job still running ...
2023/02/12 15:27:17 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-12_07_18_15-7006645845654708745 failed
--- FAIL: TestXLang_Partition (581.18s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3291.517s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676212379455443344
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38507 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@JGuRCXiLXa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@JGuRCXiLXa"}}  windowing_strategies:{key:"w0@JGuRCXiLXa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@JGuRCXiLXa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@JGuRCXiLXa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@JGuRCXiLXa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676212379455443344\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"JGuRCXiLXa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38507 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@JGuRCXiLXa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@JGuRCXiLXa"}}  windowing_strategies:{key:"w0@JGuRCXiLXa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@JGuRCXiLXa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@JGuRCXiLXa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@JGuRCXiLXa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676212379455443344\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"JGuRCXiLXa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf66640, 0xc0002f7e40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc0002f7e40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480e80?, 0xc0001179f0?}, {0x1130842, 0x39}, {0xc0002dc0c0?, 0xa97d00?, 0x1?}, {0xc000137cb0, 0xf}, 0xc000247d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480e20?, 0xc0001179f0?}, {0xc0004c6660, 0x52}, {0x1?}, {0xc000247ea8, 0x2, 0x7f7ab569e240?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137cb0, 0xf}, {0xc0004c6660, 0x52}, {0xeb4b40, 0xc0001e0fd0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003356c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003356c0, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.353s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:13be2c4760de8cafe3c7499877938cd65fc127f3b78f6bd36e3aa526b54fd8ee
Deleted: sha256:1b915dbe9bd10fcc6c749a89c94f63a6d1223d06a9611ca305be852cd9e9f64e
Deleted: sha256:635fd464be9f571c40c410f751bf364a105c93e853a5bebb2e37e4301add1dfd
Deleted: sha256:a604c1ee1e7ed82d6f00bc2490f0ade8fb0cb91bfd259fb007a3c03277a5f13b
Deleted: sha256:a8d73577a428ade6959ec12601775125b2c011c10c6ecae3c6287e8d8105cad5
Deleted: sha256:0cb74e1ab3e4220d08b9a155e07c0f1b8904f0bf01781a1efa95036c6e0dae17
Deleted: sha256:bc4740d2188ef2bedd305fc0ad98ef0b0852791afce1aa31cc762eb3b5317666
Deleted: sha256:ccf54349f1511556e1aedfc1baecb146c15d018610aab1bf541fa09fe2ca1191
Deleted: sha256:20e4f7e71cff9d1a8a5d3bae4759d4f2b4c2ffdc2ae6bd94e145278d849cf055
Deleted: sha256:3d616310db48318468084a4c7e9fe81e7863b15238fedd8b1515cc1b4298271e
Deleted: sha256:edeca813ab67c9c3605c76680fe60f341eff274474be42b50aa42e24fcb67e81
Deleted: sha256:0e658d8a50959f703e54e58270c5477797d203317871e8711a9949471fe526c7
Deleted: sha256:a5c5b7bf6a45813eab0535a3c3c2e85a1d87a5a072c171fc2f7cbe517d4db35c
Deleted: sha256:96d84c63cd71fbf6aefe9214892d74d37c8725740664f80ba41384e333fa0958
Deleted: sha256:1cc3ddf6d0e6413279a329e730018442212f8bbd79cf849858d6532408855ad7
Deleted: sha256:5415f98afdf6e36ea25bbb11e1c6d99a2f6618c41c55bee1ff783470f52bd940
Deleted: sha256:15fa9a49225f5d8e572d07563c08d7950cfefa256bbb7d4843e97174f40b8015
Deleted: sha256:7171b8230b6a7de701f417ab3a61fd963acf451f22800166a596229cb2af8dbd
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:13be2c4760de8cafe3c7499877938cd65fc127f3b78f6bd36e3aa526b54fd8ee
  Associated tags:
 - 20230212-143221
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-143221].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:13be2c4760de8cafe3c7499877938cd65fc127f3b78f6bd36e3aa526b54fd8ee].
$ rm -rf /tmp/tmp.pQRRHs4kJ3
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212142046
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212142046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212142046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:70dd5adb8ef799478e412600397244181f4ba49a794c64d4fffe2826b4fec761].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212142046
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212142046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212142046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:256f6af4cb599048c2af561234ed4bfee2d42fda6a8a00ee0f77ffd981ec5b4b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3010987.
Stopping expansion service pid: 3010988.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 26s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1280

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1280/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212082045",
            "environmentId": "nBGjWuvZnmbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229"
      }
    ]
  },
  "name": "go-testxlang_partition-104",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/12 09:17:52 Submitted job: 2023-02-12_01_17_52-5811690160910380199
2023/02/12 09:17:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-12_01_17_52-5811690160910380199?project=apache-beam-testing
2023/02/12 09:17:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-12_01_17_52-5811690160910380199
2023/02/12 09:17:52 Job state: JOB_STATE_PENDING ...
2023/02/12 09:18:22 Job still running ...
2023/02/12 09:18:52 Job still running ...
2023/02/12 09:19:23 Job still running ...
2023/02/12 09:19:53 Job still running ...
2023/02/12 09:20:23 Job still running ...
2023/02/12 09:20:53 Job still running ...
2023/02/12 09:21:23 Job still running ...
2023/02/12 09:21:53 Job still running ...
2023/02/12 09:22:23 Job still running ...
2023/02/12 09:22:53 Job still running ...
2023/02/12 09:23:23 Job still running ...
2023/02/12 09:23:53 Job still running ...
2023/02/12 09:24:23 Job still running ...
2023/02/12 09:24:53 Job still running ...
2023/02/12 09:25:23 Job still running ...
2023/02/12 09:25:53 Job still running ...
2023/02/12 09:26:23 Job still running ...
2023/02/12 09:26:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-12_01_17_52-5811690160910380199 failed
--- FAIL: TestXLang_Partition (579.72s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3259.132s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676190788175819994
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38637 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@bCkUtZwdOp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@bCkUtZwdOp"}}  windowing_strategies:{key:"w0@bCkUtZwdOp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@bCkUtZwdOp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@bCkUtZwdOp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@bCkUtZwdOp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676190788175819994\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"bCkUtZwdOp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38637 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@bCkUtZwdOp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@bCkUtZwdOp"}}  windowing_strategies:{key:"w0@bCkUtZwdOp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@bCkUtZwdOp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@bCkUtZwdOp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@bCkUtZwdOp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676190788175819994\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"bCkUtZwdOp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000650d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000650d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005c8f20?, 0xc0001179f0?}, {0x1130842, 0x39}, {0xc00015e0c0?, 0xa97d00?, 0x1?}, {0xc000137d00, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005c8ec0?, 0xc0001179f0?}, {0xc00004c660, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f2c3c7410c8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137d00, 0xf}, {0xc00004c660, 0x52}, {0xeb4b40, 0xc0000ef020})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00054ad00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00054ad00, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.427s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:46a1477e38e6c1e55653ca068b97ce4acf68815f50c75d069a5e362e366327ce
Deleted: sha256:875a4a10da33b90a2b4e40bfc1237a1615d0e19fe21a6e4d140a33eb25c9e79b
Deleted: sha256:e05b6d723c86e310c4e808631fd700db832cb02bdfe4e3802735d9d141fbf773
Deleted: sha256:cda6662913dcddf6126c9440aff4e4abe60ad2df6b9a386fe1a9c746e8aba635
Deleted: sha256:ed7f3814785ac64cc2c8ff24ae509ca0df751cbe2f0efbce85e0ff83eb5895fa
Deleted: sha256:2cedceca7142866b5cfc923df5326115ef9aca203502ad864c5110baeed99e56
Deleted: sha256:e901e69c888c5317ff7ecd94a25453a47635cb1f235eac0382124097a63cdc13
Deleted: sha256:fbc4668aa622be41c14e109eca105f69d2d4e8acd6146433b12c552273ebcdf0
Deleted: sha256:0165c5eed93e909f5a2a4a1d880f54be076115b6fb45b591fcff952447097ae3
Deleted: sha256:91417979121536a7e23fc2d753160e1f97a8ad51ec9f3d7e4dae152d2e0938ba
Deleted: sha256:efb043a7a9bf6688325b3384d006978378744af2fe0f294fea0e27fa3640a858
Deleted: sha256:5fb8c7b798024ff0367be9e4abfc65e411d675b8fcc200861a63c465b6031cd3
Deleted: sha256:425421db195a9d2f2ed13586bdf807059080a2ad8dc674dc41eee20c43a05f47
Deleted: sha256:c8fc7172cc8fb3422f954a6bf9246419b4a51df5f872c09a8a640c6931d2aae1
Deleted: sha256:108987f85312876cabc7548bd582478c16efb4e71d61e7f0d04a02df18e54ded
Deleted: sha256:903585bcf0be704de0ca535d5da496c406130a88f43246840790766cfa1c8181
Deleted: sha256:0f132f78a72d2a441046f2d0734d5134148b175a8b584762c522ce5e39e65c21
Deleted: sha256:1cf47d5a33e870a72e27a5f4fa337943c3acaa2380b94b57e2a2d15df27909b1
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:46a1477e38e6c1e55653ca068b97ce4acf68815f50c75d069a5e362e366327ce
  Associated tags:
 - 20230212-083229
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-083229].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:46a1477e38e6c1e55653ca068b97ce4acf68815f50c75d069a5e362e366327ce].
$ rm -rf /tmp/tmp.CzGSsOTfk8
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d5bc7a8aeffb101b30ceee41d6396a9c92d6693add71210b3c7f220e28f8d90a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f9c63ccf566826bc6dc005ebaa5eb1801487d85bd67ff866022712f5bde2b0a6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2579834.
Stopping expansion service pid: 2579835.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 3s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1279

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1279/display/redirect>

Changes:


------------------------------------------
[...truncated 1.00 MB...]
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212022045",
            "environmentId": "mOTKVWXipubeam:env:docker:v1"
          },
          {
            "capabilities": [
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:protocol:worker_status:v1",
              "beam:protocol:monitoring_info_short_ids:v1",
              "beam:version:sdk_base:go:apache/beam_go_sdk:2.46.0.dev",
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-023214",
            "environmentId": "go"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-023214"
      }
    ]
  },
  "name": "go-testxlang_partition-881",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/12 03:17:03 Submitted job: 2023-02-11_19_17_03-11510600479139660470
2023/02/12 03:17:03 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-11_19_17_03-11510600479139660470?project=apache-beam-testing
2023/02/12 03:17:03 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-11_19_17_03-11510600479139660470
2023/02/12 03:17:03 Job state: JOB_STATE_PENDING ...
2023/02/12 03:17:33 Job still running ...
2023/02/12 03:18:03 Job still running ...
2023/02/12 03:18:33 Job still running ...
2023/02/12 03:19:03 Job still running ...
2023/02/12 03:19:33 Job still running ...
2023/02/12 03:20:03 Job still running ...
2023/02/12 03:20:34 Job still running ...
2023/02/12 03:21:04 Job still running ...
2023/02/12 03:21:34 Job still running ...
2023/02/12 03:22:04 Job still running ...
2023/02/12 03:22:34 Job still running ...
2023/02/12 03:23:04 Job still running ...
2023/02/12 03:23:34 Job still running ...
2023/02/12 03:24:04 Job still running ...
2023/02/12 03:24:34 Job still running ...
2023/02/12 03:25:04 Job still running ...
2023/02/12 03:25:34 Job still running ...
2023/02/12 03:26:04 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-11_19_17_03-11510600479139660470 failed
--- FAIL: TestXLang_Partition (579.15s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3227.129s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676169171062620523
--- FAIL: TestBigQueryIO_BasicWriteRead (4.28s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38679 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@YKReBCZsDa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@YKReBCZsDa"}}  windowing_strategies:{key:"w0@YKReBCZsDa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@YKReBCZsDa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@YKReBCZsDa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@YKReBCZsDa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676169171062620523\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"YKReBCZsDa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38679 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@YKReBCZsDa"  is_bounded:BOUNDED  windowing_strategy_id:"w0@YKReBCZsDa"}}  windowing_strategies:{key:"w0@YKReBCZsDa"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@YKReBCZsDa"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@YKReBCZsDa"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@YKReBCZsDa"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676169171062620523\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"YKReBCZsDa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 13 [running]:
testing.tRunner.func1.2({0xf66640, 0xc0004a4980})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc0004a4980})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000501460?, 0xc00015fef0?}, {0x1130842, 0x39}, {0xc0000ee180?, 0xa97d00?, 0x1?}, {0xc000503a20, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000501400?, 0xc00015fef0?}, {0xc00004cde0, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0x7fdd48fbd638?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000503a20, 0xf}, {0xc00004cde0, 0x52}, {0xeb4b40, 0xc00018ed30})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000517040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000517040, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.319s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7b2b7cffec877aeb5b9636e3a92edbaf68bcca5224b9fc573bcee4af796eb926
  Associated tags:
 - 20230212-023214
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-023214
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230212-023214].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7b2b7cffec877aeb5b9636e3a92edbaf68bcca5224b9fc573bcee4af796eb926].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a72afcd675393ea36b968ce62c5f2f82b086c586b63efd3d6aca275591ed7202]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230212022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a72afcd675393ea36b968ce62c5f2f82b086c586b63efd3d6aca275591ed7202])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a72afcd675393ea36b968ce62c5f2f82b086c586b63efd3d6aca275591ed7202
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a72afcd675393ea36b968ce62c5f2f82b086c586b63efd3d6aca275591ed7202].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a220adb0473b1d110899177181394e098a0240b4dfde84c5b39907463c81d4c4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230212022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a220adb0473b1d110899177181394e098a0240b4dfde84c5b39907463c81d4c4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a220adb0473b1d110899177181394e098a0240b4dfde84c5b39907463c81d4c4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a220adb0473b1d110899177181394e098a0240b4dfde84c5b39907463c81d4c4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 17s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1278

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1278/display/redirect?page=changes>

Changes:

[noreply] Add support for loading torchscript models (#25321)

[noreply] [#24971] Add a retry policy for JmsIO #24971 (#24973)


------------------------------------------
[...truncated 576.62 KB...]
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211202045",
            "environmentId": "KiqnfRCWbzbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305"
      }
    ]
  },
  "name": "go-testxlang_partition-57",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/11 21:17:26 Submitted job: 2023-02-11_13_17_26-11929573355574748493
2023/02/11 21:17:26 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-11_13_17_26-11929573355574748493?project=apache-beam-testing
2023/02/11 21:17:26 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-11_13_17_26-11929573355574748493
2023/02/11 21:17:26 Job state: JOB_STATE_PENDING ...
2023/02/11 21:17:56 Job still running ...
2023/02/11 21:18:26 Job still running ...
2023/02/11 21:18:56 Job still running ...
2023/02/11 21:19:26 Job still running ...
2023/02/11 21:19:56 Job still running ...
2023/02/11 21:20:26 Job still running ...
2023/02/11 21:20:57 Job still running ...
2023/02/11 21:21:27 Job still running ...
2023/02/11 21:21:57 Job still running ...
2023/02/11 21:22:27 Job still running ...
2023/02/11 21:22:57 Job still running ...
2023/02/11 21:23:27 Job still running ...
2023/02/11 21:23:57 Job still running ...
2023/02/11 21:24:27 Job still running ...
2023/02/11 21:24:57 Job still running ...
2023/02/11 21:25:27 Job still running ...
2023/02/11 21:25:57 Job still running ...
2023/02/11 21:26:27 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-11_13_17_26-11929573355574748493 failed
--- FAIL: TestXLang_Partition (579.44s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3198.516s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676147622623267257
--- FAIL: TestBigQueryIO_BasicWriteRead (4.44s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33325 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wnNLbIqanp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wnNLbIqanp"}}  windowing_strategies:{key:"w0@wnNLbIqanp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wnNLbIqanp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wnNLbIqanp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wnNLbIqanp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676147622623267257\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wnNLbIqanp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33325 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@wnNLbIqanp"  is_bounded:BOUNDED  windowing_strategy_id:"w0@wnNLbIqanp"}}  windowing_strategies:{key:"w0@wnNLbIqanp"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@wnNLbIqanp"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@wnNLbIqanp"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@wnNLbIqanp"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676147622623267257\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"wnNLbIqanp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 41 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000560d00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000560d00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048c900?, 0xc00049a050?}, {0x1130842, 0x39}, {0xc0000f0180?, 0xa97d00?, 0x1?}, {0xc000043d90, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048c8a0?, 0xc00049a050?}, {0xc0005403c0, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7fcc6147da08?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043d90, 0xf}, {0xc0005403c0, 0x52}, {0xeb4b40, 0xc00048e2d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ad860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ad860, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.475s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.034s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7d4e6be8eda45098f70296d8f8500f15bc13ced18119f1cd860317166e933bbb
Deleted: sha256:9b54dabcd8fe30ab5cf26d54b3a9f1773443ba50f47babde5dacf21899d39a30
Deleted: sha256:d6cbe5c273c9dafe4793c03a69fac0439e89e3f8bfd83de3037d24539cb7a64b
Deleted: sha256:c519f523482ed4f7e92c1185c59512d1360a4a28655abcdf2328ba7cc22005a6
Deleted: sha256:59f0a0400d2308fd1ab79fec9780ab54667f588eb6d1722bbf3009ba860e19b2
Deleted: sha256:43453b4d82a09635142cb9b21e74ba22b8c3071829a98938567d6ead920e6f8c
Deleted: sha256:9eb454af262dc0f420fd5087dd29958209789d6c875f6115bb870537c6679a81
Deleted: sha256:f8254284351ca60562853451c102dc012892bfa1e6647476a24bc054339a14b6
Deleted: sha256:94310222a5a3dc924d1456139e58cdcff5b87ea71dce37afee24fe222d516d5a
Deleted: sha256:2d72620ba0b88cc68417ad30ede0fc636e6a50e68d0cdabc574279ce8f3741b9
Deleted: sha256:db6df49a61237173bf9dfe244163df849d37215f37f341f7c9ffd5e4c7d1a7ac
Deleted: sha256:80fbdc9e5a51ecc254e839ea8c71ce56efebc0efab4e0e90cd1c0f3fce370344
Deleted: sha256:4b9157ece7f43f46903a0de091702904bf90dab0f2761b6811ddb40234dde6dd
Deleted: sha256:18fb630d0b4c13a919cd98c67f859fdb3aff3eac51ef4e5e84705dbb994f4aaf
Deleted: sha256:41f3b69e24ac77a5fcaf228d90d30b4e98aac9f096d6ae055c923cd701ecd2d0
Deleted: sha256:9e4a7c3ed2b93206402da6934a0be0230c5d2e9e5af7c6335104ba109738068a
Deleted: sha256:a0c316be27613cd8ca67b7b331dc6cb402011c286304cc8c0476c430d1fcec61
Deleted: sha256:a070f21d78e976dc11dbe02d25884a8979b899efecf43db405beac85fed6f3d9
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7d4e6be8eda45098f70296d8f8500f15bc13ced18119f1cd860317166e933bbb
  Associated tags:
 - 20230211-203305
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-203305].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7d4e6be8eda45098f70296d8f8500f15bc13ced18119f1cd860317166e933bbb].
$ rm -rf /tmp/tmp.FGDyvOnsZC
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:40902b9abdef4e3a1c73ea75cfcb60a171a7843456ca0a607d1ccba653949f34].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6910f771b2c3a508de935b721978e8dee7dc9208bdab718f1faa4ae3c12e518c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2330296.
Stopping expansion service pid: 2330297.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 38s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1277

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1277/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211142047",
            "environmentId": "JRoKuqbfzdbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228"
      }
    ]
  },
  "name": "go-testxlang_partition-80",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/11 15:17:50 Submitted job: 2023-02-11_07_17_49-4596257000662206858
2023/02/11 15:17:50 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-11_07_17_49-4596257000662206858?project=apache-beam-testing
2023/02/11 15:17:50 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-11_07_17_49-4596257000662206858
2023/02/11 15:17:50 Job state: JOB_STATE_PENDING ...
2023/02/11 15:18:20 Job still running ...
2023/02/11 15:18:50 Job still running ...
2023/02/11 15:19:20 Job still running ...
2023/02/11 15:19:50 Job still running ...
2023/02/11 15:20:20 Job still running ...
2023/02/11 15:20:50 Job still running ...
2023/02/11 15:21:21 Job still running ...
2023/02/11 15:21:51 Job still running ...
2023/02/11 15:22:21 Job still running ...
2023/02/11 15:22:51 Job still running ...
2023/02/11 15:23:21 Job still running ...
2023/02/11 15:23:51 Job still running ...
2023/02/11 15:24:21 Job still running ...
2023/02/11 15:24:51 Job still running ...
2023/02/11 15:25:21 Job still running ...
2023/02/11 15:25:51 Job still running ...
2023/02/11 15:26:21 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-11_07_17_49-4596257000662206858 failed
--- FAIL: TestXLang_Partition (549.70s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3230.579s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676125984197307493
--- FAIL: TestBigQueryIO_BasicWriteRead (4.41s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41819 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qcimBGQcZT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qcimBGQcZT"}}  windowing_strategies:{key:"w0@qcimBGQcZT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qcimBGQcZT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qcimBGQcZT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qcimBGQcZT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676125984197307493\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qcimBGQcZT"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41819 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@qcimBGQcZT"  is_bounded:BOUNDED  windowing_strategy_id:"w0@qcimBGQcZT"}}  windowing_strategies:{key:"w0@qcimBGQcZT"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@qcimBGQcZT"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@qcimBGQcZT"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@qcimBGQcZT"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676125984197307493\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"qcimBGQcZT"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf66640, 0xc00069cc80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc00069cc80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000488f00?, 0xc0001159f0?}, {0x1130842, 0x39}, {0xc00015c0c0?, 0xa97d00?, 0x1?}, {0xc00048ad30, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000488ea0?, 0xc0001159f0?}, {0xc0000da3c0, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f108cebaa10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ad30, 0xf}, {0xc0000da3c0, 0x52}, {0xeb4b40, 0xc0006980a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a8d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a8d00, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.449s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:71b007fca44f7df337343ab7d81420502e88ac3c07bf743f0135ac1e0aae5ea5
Deleted: sha256:59e7b9d0eccfd4e8347caf34fc26970fadae0c38057a73ebd81a46668b6f0615
Deleted: sha256:5b3e2e7169ae0e02308088f5622b184c4ed1f70ebe9e025ea565f10f08f8367f
Deleted: sha256:36d4ee46ddb9691cb93291259834652a5c500bc93b1fa4b1a83e756110c4a1a6
Deleted: sha256:e6e0eacd21f70a5460dafdd3532a6f283fd317cffd5172e18c47361fb3b7b9b7
Deleted: sha256:d91418593d4a9cdd517d11fc215e7ea65264bebeea54f0c5ec607f7e320062e6
Deleted: sha256:9722cd51944f0ec459db21b1c1d5912e4ad0840b85b3c665982ef3d83079eb7e
Deleted: sha256:488a45648e886751ba1368f3c055676827577fc820750471764936c81a627a1a
Deleted: sha256:94b0250eef020a1f3d6654f38e56e028e222a9304dea4e6da30f15d5659ea804
Deleted: sha256:50e4aa43412ca0203a32e45a96f68c61cd5a541af522226fe82c74f1acb48de6
Deleted: sha256:91dc2b559d2b8d478d228d08cd32d50c92d5099069a4ef7b1bfa0c4259b61b20
Deleted: sha256:471c5f8c52870acf5bb902b006753ebd9881fe963a44a701e2c7bfa0bd06d598
Deleted: sha256:32faafd5db651808aa0ff01d584984c229761ae57f6ad065d94e98fca116d3dd
Deleted: sha256:c6ab38dfccc85e3a2a3027b817d71d3d5a5482180de0bd734305c00558d6f9e9
Deleted: sha256:99872a61d7773960e27927c65cfbcb0db8e6601718b12624a43b7c1cdcf5e1e4
Deleted: sha256:389cdc2be29c234845df8f4d6f89565aaa24a40581a40e8adcddb146f9354449
Deleted: sha256:7b38d5a899027c48bf711906100bbc4564b3ef99b9e37ed27a7d07bcf47a28d3
Deleted: sha256:bf865cb2ed6939ad27d030c0a76456731a1aaa86a10d3b0f65b3ca3f723b63a9
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:71b007fca44f7df337343ab7d81420502e88ac3c07bf743f0135ac1e0aae5ea5
  Associated tags:
 - 20230211-143228
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-143228].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:71b007fca44f7df337343ab7d81420502e88ac3c07bf743f0135ac1e0aae5ea5].
$ rm -rf /tmp/tmp.LmRupjmErV
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:293adef73e3347b490fc2a9e00d5c286ec701dbc4fda130f44675dc130af9bf0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c3d2adfd6b5540b7e9e8790855bae4bc1a7a152a0f0d79ee2b0504bc29073155].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 2182173.
Stopping expansion service pid: 2182174.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 30s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/4blj5mahk6muq

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1276

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1276/display/redirect>

Changes:


------------------------------------------
[...truncated 1.02 MB...]
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-083335",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211082051",
            "environmentId": "yZDnkztrBEbeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-083335"
      }
    ]
  },
  "name": "go-testxlang_partition-823",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/11 09:19:25 Submitted job: 2023-02-11_01_19_25-1000827603523141106
2023/02/11 09:19:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-11_01_19_25-1000827603523141106?project=apache-beam-testing
2023/02/11 09:19:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-11_01_19_25-1000827603523141106
2023/02/11 09:19:25 Job state: JOB_STATE_PENDING ...
2023/02/11 09:19:55 Job still running ...
2023/02/11 09:20:25 Job still running ...
2023/02/11 09:20:55 Job still running ...
2023/02/11 09:21:25 Job still running ...
2023/02/11 09:21:56 Job still running ...
2023/02/11 09:22:26 Job still running ...
2023/02/11 09:22:56 Job still running ...
2023/02/11 09:23:26 Job still running ...
2023/02/11 09:23:56 Job still running ...
2023/02/11 09:24:26 Job still running ...
2023/02/11 09:24:56 Job still running ...
2023/02/11 09:25:26 Job still running ...
2023/02/11 09:25:56 Job still running ...
2023/02/11 09:26:26 Job still running ...
2023/02/11 09:26:56 Job still running ...
2023/02/11 09:27:26 Job still running ...
2023/02/11 09:27:56 Job still running ...
2023/02/11 09:28:26 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-11_01_19_25-1000827603523141106 failed
--- FAIL: TestXLang_Partition (579.65s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3288.829s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676104451122802014
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34361 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@QTxZHgeWrr"  is_bounded:BOUNDED  windowing_strategy_id:"w0@QTxZHgeWrr"}}  windowing_strategies:{key:"w0@QTxZHgeWrr"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@QTxZHgeWrr"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@QTxZHgeWrr"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@QTxZHgeWrr"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676104451122802014\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"QTxZHgeWrr"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34361 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@QTxZHgeWrr"  is_bounded:BOUNDED  windowing_strategy_id:"w0@QTxZHgeWrr"}}  windowing_strategies:{key:"w0@QTxZHgeWrr"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@QTxZHgeWrr"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@QTxZHgeWrr"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@QTxZHgeWrr"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676104451122802014\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"QTxZHgeWrr"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000112580})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000112580})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000118ee0?, 0xc000117680?}, {0x1130842, 0x39}, {0xc0001d20c0?, 0xa97d00?, 0x1?}, {0xc0000430e0, 0xf}, 0xc000225d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000118e80?, 0xc000117680?}, {0xc000146300, 0x52}, {0x1?}, {0xc000225ea8, 0x2, 0x7f9ea1cdac20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0000430e0, 0xf}, {0xc000146300, 0x52}, {0xeb4b40, 0xc0001a8ba0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000007860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000007860, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.373s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.037s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:80de71d51d2316a13689c02f928947a419ed6d3892a375fcfa11add3922a79d9
  Associated tags:
 - 20230211-083335
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-083335
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-083335].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:80de71d51d2316a13689c02f928947a419ed6d3892a375fcfa11add3922a79d9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211082051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a84663d6ec0744026683b631cd083fc1733c41fca78eb56e0298988c2adf32bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211082051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a84663d6ec0744026683b631cd083fc1733c41fca78eb56e0298988c2adf32bb])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a84663d6ec0744026683b631cd083fc1733c41fca78eb56e0298988c2adf32bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a84663d6ec0744026683b631cd083fc1733c41fca78eb56e0298988c2adf32bb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211082051]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f90b0df0226229b540ffa3396b957beae1bf1c8b9c54cfe812da4afaf91e84ff]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211082051] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f90b0df0226229b540ffa3396b957beae1bf1c8b9c54cfe812da4afaf91e84ff])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f90b0df0226229b540ffa3396b957beae1bf1c8b9c54cfe812da4afaf91e84ff
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f90b0df0226229b540ffa3396b957beae1bf1c8b9c54cfe812da4afaf91e84ff].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 34s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1275

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1275/display/redirect?page=changes>

Changes:

[noreply] [#25417][go] copy env details to dataflow images (#25431)

[noreply] Update jupyter-client requirement from <6.1.13,>=6.1.11 to

[noreply] Add runtime metric to TFT tests (#25242)

[noreply] Fix typo tranform; workaround non-ascii char (#25428)


------------------------------------------
[...truncated 1017.89 KB...]
              "beam:coder:double:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:kv:v1",
              "beam:coder:iterable:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:row:v1",
              "beam:coder:nullable:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-023323",
            "environmentId": "go"
          },
          {
            "capabilities": [
              "beam:coder:bytes:v1",
              "beam:coder:bool:v1",
              "beam:coder:varint:v1",
              "beam:coder:string_utf8:v1",
              "beam:coder:iterable:v1",
              "beam:coder:timer:v1",
              "beam:coder:kv:v1",
              "beam:coder:length_prefix:v1",
              "beam:coder:global_window:v1",
              "beam:coder:interval_window:v1",
              "beam:coder:custom_window:v1",
              "beam:coder:windowed_value:v1",
              "beam:coder:double:v1",
              "beam:coder:row:v1",
              "beam:coder:param_windowed_value:v1",
              "beam:coder:state_backed_iterable:v1",
              "beam:coder:sharded_key:v1",
              "beam:coder:nullable:v1",
              "beam:protocol:multi_core_bundle_processing:v1",
              "beam:protocol:progress_reporting:v1",
              "beam:protocol:harness_monitoring_infos:v1",
              "beam:protocol:control_request_elements_embedding:v1",
              "beam:protocol:state_caching:v1",
              "beam:version:sdk_base:apache/beam_java8_sdk:2.46.0.dev",
              "beam:transform:sdf_truncate_sized_restrictions:v1",
              "beam:transform:to_string:v1"
            ],
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211022048",
            "environmentId": "orVNLbekhabeam:env:docker:v1"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-023323"
      }
    ]
  },
  "name": "go-testxlang_partition-765",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/11 03:20:03 Submitted job: 2023-02-10_19_20_03-11622615378219980156
2023/02/11 03:20:03 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-10_19_20_03-11622615378219980156?project=apache-beam-testing
2023/02/11 03:20:03 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-10_19_20_03-11622615378219980156
2023/02/11 03:20:03 Job state: JOB_STATE_PENDING ...
2023/02/11 03:20:33 Job still running ...
2023/02/11 03:21:04 Job still running ...
2023/02/11 03:21:34 Job still running ...
2023/02/11 03:22:04 Job still running ...
2023/02/11 03:22:34 Job still running ...
2023/02/11 03:23:04 Job still running ...
2023/02/11 03:23:34 Job still running ...
2023/02/11 03:24:04 Job still running ...
2023/02/11 03:24:34 Job still running ...
2023/02/11 03:25:04 Job still running ...
2023/02/11 03:25:34 Job still running ...
2023/02/11 03:26:04 Job still running ...
2023/02/11 03:26:34 Job still running ...
2023/02/11 03:27:04 Job still running ...
2023/02/11 03:27:34 Job still running ...
2023/02/11 03:28:04 Job still running ...
2023/02/11 03:28:34 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-10_19_20_03-11622615378219980156 failed
--- FAIL: TestXLang_Partition (549.64s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3306.106s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676082846247912161
--- FAIL: TestBigQueryIO_BasicWriteRead (7.00s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42911 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@AESfUZDhdw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@AESfUZDhdw"}}  windowing_strategies:{key:"w0@AESfUZDhdw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@AESfUZDhdw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@AESfUZDhdw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@AESfUZDhdw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676082846247912161\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"AESfUZDhdw"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42911 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@AESfUZDhdw"  is_bounded:BOUNDED  windowing_strategy_id:"w0@AESfUZDhdw"}}  windowing_strategies:{key:"w0@AESfUZDhdw"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@AESfUZDhdw"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@AESfUZDhdw"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@AESfUZDhdw"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676082846247912161\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"AESfUZDhdw"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf66640, 0xc00048ccc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc00048ccc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00051cfc0?, 0xc0005057c0?}, {0x1130842, 0x39}, {0xc0000f00c0?, 0xa97d00?, 0x1?}, {0xc000490c60, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00051cf60?, 0xc0005057c0?}, {0xc0006183c0, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0x7f830b14f7a8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000490c60, 0xf}, {0xc0006183c0, 0x52}, {0xeb4b40, 0xc000491f70})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103520, 0x11626a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	10.034s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.057s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c179a23474f8dbae7b6d8f0b0b2652b3f50a732eb25904066d45f56f6f22d764
  Associated tags:
 - 20230211-023323
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-023323
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230211-023323].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c179a23474f8dbae7b6d8f0b0b2652b3f50a732eb25904066d45f56f6f22d764].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7911092b07bb325a25e3d7264ba8051e892ebe7b25f888b5b4f4bef57434636b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230211022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7911092b07bb325a25e3d7264ba8051e892ebe7b25f888b5b4f4bef57434636b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7911092b07bb325a25e3d7264ba8051e892ebe7b25f888b5b4f4bef57434636b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7911092b07bb325a25e3d7264ba8051e892ebe7b25f888b5b4f4bef57434636b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7869bb5702e149c0dd09b6194ff548f4e68f4db60ef442e09ebb5b9f90b73b61]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230211022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7869bb5702e149c0dd09b6194ff548f4e68f4db60ef442e09ebb5b9f90b73b61])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7869bb5702e149c0dd09b6194ff548f4e68f4db60ef442e09ebb5b9f90b73b61
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7869bb5702e149c0dd09b6194ff548f4e68f4db60ef442e09ebb5b9f90b73b61].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 44s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1274

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1274/display/redirect?page=changes>

Changes:

[chamikaramj] Update PythonMap transform to accept extra packages

[chamikaramj] Update the test

[chamikaramj] Address reviewer comments

[chamikaramj] Copy environment capabilities when creating the WorkerPool for Java

[noreply] Added MetadataSpannerConfig class for generating SpannerConfig for

[noreply] Remove ValueProvider from BigtableIO ReadChangeStream (#25409)

[noreply] Annotate Cloud Bigtable implementation details as Internal (#25403)

[noreply] Add dependencies in some examples (#25425)

[noreply] Add batching args to ModelHandlers docs (#25398)

[noreply] Data sampling proto (#25421)

[noreply] Support ONNX runtime in RunInference API  (#24911)

[noreply] Fix UpdateSchemaDestination breaking DynamicDestination in Bigquery

[noreply] Fix whitespace (#25432)


------------------------------------------
[...truncated 986.55 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-gAMwDKIBrZ2erOwNRlfgHN1KlLUTQ4FZPfc9JyJx7YI.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-gAMwDKIBrZ2erOwNRlfgHN1KlLUTQ4FZPfc9JyJx7YI.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3841/go-8-1676066248795166035/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210205730"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-211027"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-211027"
      }
    ]
  },
  "name": "go-testxlang_partition-425",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/10 21:57:37 Submitted job: 2023-02-10_13_57_37-4217440339335360150
2023/02/10 21:57:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-10_13_57_37-4217440339335360150?project=apache-beam-testing
2023/02/10 21:57:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-10_13_57_37-4217440339335360150
2023/02/10 21:57:37 Job state: JOB_STATE_PENDING ...
2023/02/10 21:58:07 Job still running ...
2023/02/10 21:58:38 Job still running ...
2023/02/10 21:59:08 Job still running ...
2023/02/10 21:59:38 Job still running ...
2023/02/10 22:00:08 Job still running ...
2023/02/10 22:00:38 Job still running ...
2023/02/10 22:01:08 Job still running ...
2023/02/10 22:01:38 Job still running ...
2023/02/10 22:02:08 Job still running ...
2023/02/10 22:02:38 Job still running ...
2023/02/10 22:03:08 Job still running ...
2023/02/10 22:03:38 Job still running ...
2023/02/10 22:04:08 Job still running ...
2023/02/10 22:04:38 Job still running ...
2023/02/10 22:05:08 Job still running ...
2023/02/10 22:05:38 Job still running ...
2023/02/10 22:06:08 Job still running ...
2023/02/10 22:06:38 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-10_13_57_37-4217440339335360150 failed
--- FAIL: TestXLang_Partition (580.35s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3355.018s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676063481637549179
--- FAIL: TestBigQueryIO_BasicWriteRead (4.43s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35347 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@sJFPnPFLAu"  is_bounded:BOUNDED  windowing_strategy_id:"w0@sJFPnPFLAu"}}  windowing_strategies:{key:"w0@sJFPnPFLAu"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@sJFPnPFLAu"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@sJFPnPFLAu"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@sJFPnPFLAu"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676063481637549179\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"sJFPnPFLAu"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35347 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@sJFPnPFLAu"  is_bounded:BOUNDED  windowing_strategy_id:"w0@sJFPnPFLAu"}}  windowing_strategies:{key:"w0@sJFPnPFLAu"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@sJFPnPFLAu"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@sJFPnPFLAu"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@sJFPnPFLAu"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676063481637549179\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"sJFPnPFLAu"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf66640, 0xc0000327c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc0000327c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048a800?, 0xc000114280?}, {0x1130828, 0x39}, {0xc00015c180?, 0xa97ee0?, 0x1?}, {0xc0000435a0, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048a7a0?, 0xc000114280?}, {0xc00004c660, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7f888857b888?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0000435a0, 0xf}, {0xc00004c660, 0x52}, {0xeb4b40, 0xc000134410})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000642d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000642d00, 0x1162680)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.465s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.039s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.066s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8681446ea33be60a1e7ec73f4eaf79b7fb0d07f0c61c32951dffb83d6e6b6ded
  Associated tags:
 - 20230210-211027
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-211027
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-211027].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8681446ea33be60a1e7ec73f4eaf79b7fb0d07f0c61c32951dffb83d6e6b6ded].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230210205730]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5445d2ff82806dcc6fb49e73ff778e02ff4ff2b6f17d2f8e6f57b700267dc0a6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230210205730] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5445d2ff82806dcc6fb49e73ff778e02ff4ff2b6f17d2f8e6f57b700267dc0a6])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5445d2ff82806dcc6fb49e73ff778e02ff4ff2b6f17d2f8e6f57b700267dc0a6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:5445d2ff82806dcc6fb49e73ff778e02ff4ff2b6f17d2f8e6f57b700267dc0a6].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210205730]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d214de60b7958912a0f2ea5109eff23d036860e12166c3f657ca2740d8d022bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210205730] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d214de60b7958912a0f2ea5109eff23d036860e12166c3f657ca2740d8d022bb])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d214de60b7958912a0f2ea5109eff23d036860e12166c3f657ca2740d8d022bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d214de60b7958912a0f2ea5109eff23d036860e12166c3f657ca2740d8d022bb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 6s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1273

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1273/display/redirect?page=changes>

Changes:

[noreply] Fix typo in args (#25422)


------------------------------------------
[...truncated 568.36 KB...]
2023/02/10 15:26:02 Job still running ...
2023/02/10 15:26:32 Job still running ...
2023/02/10 15:27:02 Job still running ...
2023/02/10 15:27:32 Job still running ...
2023/02/10 15:28:02 Job still running ...
2023/02/10 15:28:32 Job still running ...
2023/02/10 15:29:02 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-10_07_20_01-12692822645366459044 failed
--- FAIL: TestXLang_Partition (582.16s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3324.636s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676039655599395322
--- FAIL: TestBigQueryIO_BasicWriteRead (5.62s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35787 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@JcRUtDHEOd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@JcRUtDHEOd"}}  windowing_strategies:{key:"w0@JcRUtDHEOd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@JcRUtDHEOd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@JcRUtDHEOd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@JcRUtDHEOd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676039655599395322\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"JcRUtDHEOd"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35787 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@JcRUtDHEOd"  is_bounded:BOUNDED  windowing_strategy_id:"w0@JcRUtDHEOd"}}  windowing_strategies:{key:"w0@JcRUtDHEOd"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@JcRUtDHEOd"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@JcRUtDHEOd"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@JcRUtDHEOd"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1676039655599395322\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"JcRUtDHEOd"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf66640, 0xc000394440})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc000394440})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000598d20?, 0xc0001176d0?}, {0x1130828, 0x39}, {0xc00010e000?, 0xa97ee0?, 0x1?}, {0xc0001a9cf0, 0xf}, 0xc00002bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000598cc0?, 0xc0001176d0?}, {0xc000180960, 0x52}, {0x1?}, {0xc00002bea8, 0x2, 0x7f2f74235778?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001a9cf0, 0xf}, {0xc000180960, 0x52}, {0xeb4b40, 0xc0005f9010})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004caea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004caea0, 0x1162680)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.664s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.049s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-143320
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-143320
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:435e67c6643e23cf6a33b7b9db0c751774a059dbee928235b5386c0a8625c4a8
Deleted: sha256:7ff0515f989851524c6c4d0e920e3265270b6077b0e75a1d2270b753bc90ada2
Deleted: sha256:66dea4064202e4f3159bcf18c9319b47e13ab6fae6f6e475c449cbfbd8fcbfba
Deleted: sha256:7576d8c1c3e66b344a065c89846178d8bba6fcdf4be33e626b0bebb52b03b9e9
Deleted: sha256:88507432f9574c80a655aa673a7c500a8bd04efc2f44e156734a458f39e4c55a
Deleted: sha256:153b9cb28fdda11fc4eef6481becd66c5d6b2eb427731e61d6e295b9fd673387
Deleted: sha256:20963251eb661209cb03f79882797163d953025fa22f253460f689f26fd9140c
Deleted: sha256:0464ccd8ecf26dede74aa20489510863d75e4d31e1fdc9814345633a125c36c2
Deleted: sha256:c1867081e5052171601d65ac041efb68b3278f2a1d96a169abc4910cc65858c7
Deleted: sha256:7694646cc525573ba281eef2c62f76d745bb6fb3a87c9b8851382b9db1e5a73b
Deleted: sha256:ff7806248dcd4580d9c18e66d59c91fe7d05d352dbb7f6620f86cc00462de958
Deleted: sha256:a11d8193dc6b8e038b70008b6cc5214b40028c4665b21c4ab590764c4c7ebcd6
Deleted: sha256:fddaac93d6fab45bb84db92a2f6e0126363ad7ed2414eb691d2f79b423102203
Deleted: sha256:10dd8a3853b51b15ed90f8d92ab08530e98d5b2ed13a38c70fda89b2a281fb3d
Deleted: sha256:c5bf1b35b8210007ea91bdcaba245dd38a9c506d4b0cc7af604121533823b5a7
Deleted: sha256:7b7a5aaa24aca7627afbe23999fac2e9cb34002ec6f29ec572c74a1a87e87a9f
Deleted: sha256:244f5b9398828282177796a493281b49cb8fb39b6522631b8aaa030cc93e4e4c
Deleted: sha256:6962e302689dd3fd39e35078e997bf41effd122d6d8b76e1ca0534dbbc86495e
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-143320
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:435e67c6643e23cf6a33b7b9db0c751774a059dbee928235b5386c0a8625c4a8
  Associated tags:
 - 20230210-143320
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-143320
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230210-143320].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:435e67c6643e23cf6a33b7b9db0c751774a059dbee928235b5386c0a8625c4a8].
$ rm -rf /tmp/tmp.ivQ78WEZ9x
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230210142044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230210142044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230210142044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:54345ac93b9ceb8b94b742224fe03e995ed299fbd996ca55344939bf86871148].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210142044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784
Deleted: sha256:deb16c8f19f7a42e251a357ecbd146f827760cf2bc7c169597e1beed7b2dea36
Deleted: sha256:e3d7d2487c253be905c0add4316634c7d926f374adcb277044751ab5d87d824c
Deleted: sha256:1dd36ae6e73a1853d3d96ab589419a40e9f8fc224592308e5ca2eeffa513f02e
Deleted: sha256:3ab6ce914227fe3b96164a6465c0fe19051996af07b3c180dcaeb271ce3aa713
Deleted: sha256:1e59947f61046a00f9180433536718c9ec2dc8e2e5d8c467b17c573439371551
Deleted: sha256:3c2961b075fcf5464a7e50dca31832310247369e9423b345206e6553c43c8562
Deleted: sha256:f33a1a4ae3a6370ad33200b38833f2f5a566c34189ff6f9977f91c333a401e6b
Deleted: sha256:b59feb6ef208f32c44e0d77a0f2661bf7809463ee525e74b4c97840ef6aadcbf
Deleted: sha256:cc998b7db1eb5977cb81423546d091d863c963ac298613fe0f2ee6e2f3340a6f
Deleted: sha256:6121a971ba530b89b598fcbe121ec4b380c494c29d16d2d102c857ee622df06f
Deleted: sha256:2dc23eea644ae30c8acc009c6e0bf6e6e3b3623b917c83f449f9bdb819dcab72
Deleted: sha256:2601f3fb9d422d3d42752e69e2379efeadb36a89363086c2257819bd720c0f95
Deleted: sha256:b3300afab4aa565bc1e02c1e6970d20ac6cbbb7cd2204dfde603078a932a7d3a
Deleted: sha256:2b05f8bc87277ca9ea374ae2e2487bfb74c7da0f6a96e8d1468aa102f098b374
Deleted: sha256:e87d6205258c190f5e498d812932afe94f3fec040d62fd243fbfaa1b5969714c
Deleted: sha256:5ea4e43cf9ef11879091d731835a259fcfec8ac2464a8b332db1aad1683b28fb
Deleted: sha256:e5d5958949ac5eab839a765fc5dc0a819e4778a815e7487051db8cb591382052
Deleted: sha256:582c570f5dfd03e03295d9103908328853f42afdb5f9d0f0257d8435f2725544
Deleted: sha256:ca682f552a2eeb9ce18fa90daebdec41b6ac6d9026d7eec9c9679f0f2c6f5a87
Deleted: sha256:b388901bbbac3a797ea2f97453d73ee90d8640236185c65a72f60f7f66628e1e
Deleted: sha256:445fb39a5a9918fc6f03c446b8e7f7365f174c36cfde14de480de71678ed52d5
Deleted: sha256:eed027568cf71815a2a48e074f8fce546927a7fc3206d61569bc9d633eedf292
Deleted: sha256:13b4e0e14cb3ecb573007f6ef2c7d4a5081d2bd62248e51c7a4b36abcc8936e9
Deleted: sha256:ebdd2371a6a9a784c8056ef8f47144cadbaf3fc30281d5f30c38e176c5bcb154
Deleted: sha256:23cd89bdde51a1ee625ded4768e7e4e7ff1acd0273de655229a74499e3687607
Deleted: sha256:6dd0aa5be4a52a206dff9603295df7d22e03dae7df418ffe7a85282f259c12a1
Deleted: sha256:bbe5d27ae8f3f915e5e457930d287d94794d8da860f3d8d6632afb412c8b333f
Deleted: sha256:bcff38ac1d63fb243f2c32cf69663467a2d3ee6af11fcca1e7e31b9e3a56ca7b
Deleted: sha256:b9f805ce71bb1c7b8d4da4c253235c7158818dfae1f8b27f167a80cc51958ddb
Deleted: sha256:ba77a0c88dae76c6293ebb2c78e0837faf791d65f3f5c49231d7ff33dc683cb6
Deleted: sha256:6b6b15ba523e4e3b09f06ab63994740c4090849ae98f2191cb11b16df6a5f353
Deleted: sha256:d7eac5900817f0c99bbd36ada36bd2a5d9ed8a84b10d0bae5e0e9cd79c10d3ca
Deleted: sha256:77591f52d98e38415d4dff8908bcadf78d17a09b540d6ee65abd6a0ba6ff68b7
Deleted: sha256:66d458bd21cd89ae0bc27241d9e90bb2e81d970e763ee1fc2709449c8f02f252
Deleted: sha256:1b6a65d956d80c3c1d1aa86e5a057e38cc215c15b8a51166144224261d422b93
Deleted: sha256:bee5d962535d672f2c2f941ef00c8187eec685d63cd2e9cfbc237657fbfba165
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210142044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230210142044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:6e1ff711c995eea398c5253525867be2a9bfa40a961d0e2965dee584e590a784].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 65417.
Stopping expansion service pid: 65418.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 16s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1272

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1272/display/redirect?page=changes>

Changes:

[noreply] [prism] Initial commit for READMEs and go.mod (#25404)

[noreply] [prism] Add urns package (#25405)

[noreply] Add Two Counter Metric in BigQuery Write Schema Transform (#25155)

[noreply] [prism] Add internal/config package (#25406)


------------------------------------------
[...truncated 608.92 KB...]
Markdown==3.4.1
MarkupSafe==2.1.2
mmh3==3.0.0
mock==2.0.0
nltk==3.8.1
nose==1.3.7
numpy==1.24.0
oauth2client==4.1.3
oauthlib==3.2.2
objsize==0.6.1
opt-einsum==3.3.0
orjson==3.8.5
overrides==6.5.0
packaging==23.0
pandas==1.5.3
parameterized==0.8.1
pbr==5.11.1
pip==23.0
pluggy==1.0.0
proto-plus==1.22.2
protobuf==3.19.6
psycopg2-binary==2.9.5
py==1.11.0
pyarrow==9.0.0
pyasn1==0.4.8
pyasn1-modules==0.2.8
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.2.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container 6d00d76057b6
 ---> 29425f5ade64
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> ab6e4a50224e
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 14008d4aa531
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 8598f4a99e66
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 60875e2d26be
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in e403734ee0a5
Removing intermediate container e403734ee0a5
 ---> 5e20ff813e94
Step 22/32 : FROM beam as third_party_licenses
 ---> 5e20ff813e94
Step 23/32 : ARG pull_licenses
 ---> Running in 9bee40fae8b7
Removing intermediate container 9bee40fae8b7
 ---> 0d1f564266f9
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 55916ce77a1d
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> aaa407d709d4
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 7bd9baa1e7c8
Removing intermediate container 7bd9baa1e7c8
 ---> 3371c3a17a4c
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 981f28398529
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in ef964ad4c8b2
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=56281dccaea71a987b669a6c573390b91ba72552758a58e671c0ad2ca1b6293e
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
INFO:root:Successfully pulled licenses for 136 dependencies
Skip pulling license for  bs4
Removing intermediate container ef964ad4c8b2
 ---> 382c408ef392
Step 29/32 : FROM beam
 ---> 5e20ff813e94
Step 30/32 : ARG pull_licenses
 ---> Running in 683e6eadadfa
Removing intermediate container 683e6eadadfa
 ---> beef064ffecf
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> 99885abc1196
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 39c2e432c99d
Removing intermediate container 39c2e432c99d
 ---> ab5d46c616e7
Successfully built ab5d46c616e7
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
98859e50cd93: Preparing
114cad8e0919: Preparing
3f06b3d7add1: Preparing
b8c4e1dacd04: Preparing
23bbbd93ae67: Preparing
5b2f6b6af5bd: Preparing
7159b198f5c6: Preparing
90a127f8d835: Preparing
993aad141f71: Preparing
f0b0b80604a3: Preparing
9ec8bc14f7aa: Preparing
2708391ae225: Preparing
e3c73e61b2ee: Preparing
4665262d34dc: Preparing
da094707be5c: Preparing
354742515b6e: Preparing
44d4ac3b1960: Preparing
e4c97b13f26a: Preparing
52fb12b3f764: Preparing
0dafd2b156dd: Preparing
152e2eadff76: Preparing
738226f36892: Preparing
8fcfc59d80ac: Preparing
5b2f6b6af5bd: Waiting
4665262d34dc: Waiting
7159b198f5c6: Waiting
90a127f8d835: Waiting
993aad141f71: Waiting
da094707be5c: Waiting
f0b0b80604a3: Waiting
354742515b6e: Waiting
9ec8bc14f7aa: Waiting
44d4ac3b1960: Waiting
2708391ae225: Waiting
e4c97b13f26a: Waiting
e3c73e61b2ee: Waiting
52fb12b3f764: Waiting
738226f36892: Waiting
0dafd2b156dd: Waiting
152e2eadff76: Waiting
3f06b3d7add1: Pushed
b8c4e1dacd04: Pushed
23bbbd93ae67: Pushed
98859e50cd93: Pushed
114cad8e0919: Pushed
993aad141f71: Pushed
90a127f8d835: Pushed
7159b198f5c6: Pushed
e3c73e61b2ee: Pushed
4665262d34dc: Pushed
9ec8bc14f7aa: Pushed
da094707be5c: Layer already exists
354742515b6e: Layer already exists
44d4ac3b1960: Layer already exists
e4c97b13f26a: Layer already exists
52fb12b3f764: Layer already exists
0dafd2b156dd: Layer already exists
152e2eadff76: Layer already exists
738226f36892: Layer already exists
8fcfc59d80ac: Layer already exists
5b2f6b6af5bd: Pushed
f0b0b80604a3: Pushed
2708391ae225: Pushed
20230210022223: digest: sha256:722e845980de34ec9101fd1e074f6c32d06bf63d30e4029c183aab4de4dfd723 size: 5156

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:java:container:pullLicenses'.
> Process 'command './license_scripts/license_script.sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 18m 37s
207 actionable tasks: 141 executed, 54 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1271

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1271/display/redirect?page=changes>

Changes:

[noreply] fix doc on bq sxtorage (#25353)

[noreply] [Playground] Fix Test_getRunOrTestCmd on Go 1.20 (#25379)

[noreply] Fix typo - metdata -> metadata (#25399)


------------------------------------------
[...truncated 526.77 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-LR9tPqzRjjWXelLMuofyjRl-OyTbCDtmip8IueTqle8.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-LR9tPqzRjjWXelLMuofyjRl-OyTbCDtmip8IueTqle8.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test11560/go-8-1675978526104830931/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-204704"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209203122"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-204704"
      }
    ]
  },
  "name": "go-testxlang_partition-756",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/09 21:35:36 Submitted job: 2023-02-09_13_35_36-6416146733691437201
2023/02/09 21:35:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-09_13_35_36-6416146733691437201?project=apache-beam-testing
2023/02/09 21:35:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-09_13_35_36-6416146733691437201
2023/02/09 21:35:36 Job state: JOB_STATE_PENDING ...
2023/02/09 21:36:06 Job still running ...
2023/02/09 21:36:37 Job still running ...
2023/02/09 21:37:07 Job still running ...
2023/02/09 21:37:37 Job still running ...
2023/02/09 21:38:07 Job still running ...
2023/02/09 21:38:37 Job still running ...
2023/02/09 21:39:07 Job still running ...
2023/02/09 21:39:37 Job still running ...
2023/02/09 21:40:07 Job still running ...
2023/02/09 21:40:37 Job still running ...
2023/02/09 21:41:07 Job still running ...
2023/02/09 21:41:37 Job still running ...
2023/02/09 21:42:07 Job still running ...
2023/02/09 21:42:37 Job still running ...
2023/02/09 21:43:07 Job still running ...
2023/02/09 21:43:37 Job still running ...
2023/02/09 21:44:07 Job still running ...
2023/02/09 21:44:37 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-09_13_35_36-6416146733691437201 failed
--- FAIL: TestXLang_Partition (581.96s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3436.044s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675975679753239565
--- FAIL: TestBigQueryIO_BasicWriteRead (7.10s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44437 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@cdwNmyntyv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@cdwNmyntyv"}}  windowing_strategies:{key:"w0@cdwNmyntyv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@cdwNmyntyv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@cdwNmyntyv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@cdwNmyntyv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675975679753239565\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"cdwNmyntyv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44437 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2"  value:{unique_name:"n2"  coder_id:"c0@cdwNmyntyv"  is_bounded:BOUNDED  windowing_strategy_id:"w0@cdwNmyntyv"}}  windowing_strategies:{key:"w0@cdwNmyntyv"  value:{window_fn:{urn:"beam:window_fn:global_windows:v1"}  merge_status:NON_MERGING  window_coder_id:"c1@cdwNmyntyv"  trigger:{default:{}}  accumulation_mode:DISCARDING  output_time:END_OF_WINDOW  closing_behavior:EMIT_IF_NONEMPTY  on_time_behavior:FIRE_IF_NONEMPTY  environment_id:"go"}}  coders:{key:"c0@cdwNmyntyv"  value:{spec:{urn:"beam:coder:row:v1"  payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}}  coders:{key:"c1@cdwNmyntyv"  value:{spec:{urn:"beam:coder:global_window:v1"}}}}  transform:{unique_name:"External"  spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1"  payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675975679753239565\x05Never"}  inputs:{key:"i0"  value:"n2"}  environment_id:"go"}  namespace:"cdwNmyntyv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 57 [running]:
testing.tRunner.func1.2({0xf66640, 0xc00066c600})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66640, 0xc00066c600})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480780?, 0xc0000c02d0?}, {0x1130828, 0x39}, {0xc0000f60c0?, 0xa97ee0?, 0x1?}, {0xc000043de0, 0xf}, 0xc0004fbd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480720?, 0xc0000c02d0?}, {0xc0004ac300, 0x52}, {0x1?}, {0xc0004fbea8, 0x2, 0xe73b20?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043de0, 0xf}, {0xc0004ac300, 0x52}, {0xeb4b40, 0xc0004001b8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x1162680)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	10.141s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.050s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.042s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.061s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4de6065c337690fbbd0286a8d7a99b3440991b68e0139b311d78502815b83d06
  Associated tags:
 - 20230209-204704
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-204704
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-204704].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4de6065c337690fbbd0286a8d7a99b3440991b68e0139b311d78502815b83d06].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209203122]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:18b95f494ff0848a5a4340057ab07a010f2e42957460f06277de76c599d82f36]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209203122] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:18b95f494ff0848a5a4340057ab07a010f2e42957460f06277de76c599d82f36])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:18b95f494ff0848a5a4340057ab07a010f2e42957460f06277de76c599d82f36
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:18b95f494ff0848a5a4340057ab07a010f2e42957460f06277de76c599d82f36].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209203122]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:45751b1d5691b33142bb2fdbb2058abb13acf159d96c7f725a399d3f03e001ef]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209203122] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:45751b1d5691b33142bb2fdbb2058abb13acf159d96c7f725a399d3f03e001ef])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:45751b1d5691b33142bb2fdbb2058abb13acf159d96c7f725a399d3f03e001ef
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:45751b1d5691b33142bb2fdbb2058abb13acf159d96c7f725a399d3f03e001ef].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 14m 31s
216 actionable tasks: 155 executed, 49 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1270

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1270/display/redirect?page=changes>

Changes:

[noreply] Bump google.golang.org/api from 0.108.0 to 0.109.0 in /sdks (#25250)

[noreply] Add min and max batch size args to model handler (#25395)

[noreply] Beam/sdks/io/gcp/java/healcare/hl7v2 io read (#25056)

[noreply] Remove reuse of GenericRecord instance when reading Avro from BigQuery

[noreply] fixed reading env variable (#25362)


------------------------------------------
[...truncated 601.20 KB...]
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.2.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container dc38689a2f30
 ---> a1f7de65e72d
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> f74c01acb530
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> c6460f28d664
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 2e7094275f13
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 3213e5647851
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in cf3fef9868b1
Removing intermediate container cf3fef9868b1
 ---> fb50d6e05ea1
Step 22/32 : FROM beam as third_party_licenses
 ---> fb50d6e05ea1
Step 23/32 : ARG pull_licenses
 ---> Running in 4954084fb418
Removing intermediate container 4954084fb418
 ---> 71debef18d6c
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 4e7ffb74db0f
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> b799c88f8d91
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 3100afdb160d
Removing intermediate container 3100afdb160d
 ---> d32ac80a12c3
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 726ba717d557
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in d75ee824c581
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=ced737f9d16f899cb83562aa5c8395e17143b82914fc41103468fd356e2cdbd5
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
INFO:root:Successfully pulled licenses for 136 dependencies
Skip pulling license for  bs4
Removing intermediate container d75ee824c581
 ---> e01529c46237
Step 29/32 : FROM beam
 ---> fb50d6e05ea1
Step 30/32 : ARG pull_licenses
 ---> Running in 554d616ea09e
Removing intermediate container 554d616ea09e
 ---> 0dad55ef32b0
Step 31/32 : COPY --from=third_party_licenses /opt/apache/beam/third_party_licenses /opt/apache/beam/third_party_licenses
 ---> c4cb7f58ec38
Step 32/32 : RUN if [ "$pull_licenses" != "true" ] ; then       rm -rf /opt/apache/beam/third_party_licenses ;     fi
 ---> Running in 809954c76ef9
Removing intermediate container 809954c76ef9
 ---> 3c3311b562a3
Successfully built 3c3311b562a3
Successfully tagged apache/beam_python3.8_sdk:2.46.0.dev

> Task :runners:google-cloud-dataflow-java:buildAndPushDockerPythonContainer
WARNING: `gcloud docker` will not be supported for Docker client versions above 18.03.

As an alternative, use `gcloud auth configure-docker` to configure `docker` to
use `gcloud` as a credential helper, then use `docker` as you would for non-GCR
registries, e.g. `docker pull gcr.io/project-id/my-image`. Add
`--verbosity=error` to silence this warning: `gcloud docker
--verbosity=error -- pull gcr.io/project-id/my-image`.

See: https://cloud.google.com/container-registry/docs/support/deprecation-notices#gcloud-docker

The push refers to repository [us.gcr.io/apache-beam-testing/java-postcommit-it/python]
07af18c5fe41: Preparing
5588be066148: Preparing
bb7daa1b68a8: Preparing
3850a9e34cad: Preparing
4a615a257b7a: Preparing
f712eba23737: Preparing
47aeece9a1d3: Preparing
7eab93e22424: Preparing
639a655cb70d: Preparing
6471872c5436: Preparing
5c5b3e2fed20: Preparing
bb95d4c9fa9b: Preparing
a3b657564d54: Preparing
762d878a4d9d: Preparing
da094707be5c: Preparing
354742515b6e: Preparing
44d4ac3b1960: Preparing
e4c97b13f26a: Preparing
52fb12b3f764: Preparing
0dafd2b156dd: Preparing
152e2eadff76: Preparing
738226f36892: Preparing
8fcfc59d80ac: Preparing
bb95d4c9fa9b: Waiting
a3b657564d54: Waiting
f712eba23737: Waiting
762d878a4d9d: Waiting
47aeece9a1d3: Waiting
7eab93e22424: Waiting
da094707be5c: Waiting
639a655cb70d: Waiting
6471872c5436: Waiting
354742515b6e: Waiting
152e2eadff76: Waiting
5c5b3e2fed20: Waiting
8fcfc59d80ac: Waiting
738226f36892: Waiting
0dafd2b156dd: Waiting
52fb12b3f764: Waiting
e4c97b13f26a: Waiting
3850a9e34cad: Pushed
4a615a257b7a: Pushed
bb7daa1b68a8: Pushed
07af18c5fe41: Pushed
5588be066148: Pushed
639a655cb70d: Pushed
7eab93e22424: Pushed
47aeece9a1d3: Pushed
a3b657564d54: Pushed
762d878a4d9d: Pushed
da094707be5c: Layer already exists
5c5b3e2fed20: Pushed
354742515b6e: Layer already exists
44d4ac3b1960: Layer already exists
e4c97b13f26a: Layer already exists
52fb12b3f764: Layer already exists
0dafd2b156dd: Layer already exists
152e2eadff76: Layer already exists
738226f36892: Layer already exists
8fcfc59d80ac: Layer already exists
f712eba23737: Pushed
6471872c5436: Pushed
bb95d4c9fa9b: Pushed
20230209151236: digest: sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8 size: 5156

> Task :runners:google-cloud-dataflow-java:setupXVR
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209151236
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209151236]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209151236] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:26f7de2a02fb09f48a3b935c211bfa473d5a51a354ff72048969c602aa0a49b8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209151236
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209151236]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209151236] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b25882bbdcef466112cf69323f0435f7251ac7723b6a407541a0ec088e0ab398].

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:installGcpTest'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 17m 39s
213 actionable tasks: 146 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1269

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1269/display/redirect?page=changes>

Changes:

[noreply] Adding support for @SchemaFieldDescription annotation that allows ann…

[noreply] Adding SpannerIO.readChangeStreams support for SchemaTransform (#24999)


------------------------------------------
[...truncated 526.36 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-LR9tPqzRjjWXelLMuofyjRl-OyTbCDtmip8IueTqle8.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-LR9tPqzRjjWXelLMuofyjRl-OyTbCDtmip8IueTqle8.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10426/go-8-1675934340464977861/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209082048"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-083245"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-083245"
      }
    ]
  },
  "name": "go-testxlang_partition-423",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/09 09:19:09 Submitted job: 2023-02-09_01_19_08-7730121794154403315
2023/02/09 09:19:09 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-09_01_19_08-7730121794154403315?project=apache-beam-testing
2023/02/09 09:19:09 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-09_01_19_08-7730121794154403315
2023/02/09 09:19:09 Job state: JOB_STATE_PENDING ...
2023/02/09 09:19:39 Job still running ...
2023/02/09 09:20:09 Job still running ...
2023/02/09 09:20:39 Job still running ...
2023/02/09 09:21:09 Job still running ...
2023/02/09 09:21:39 Job still running ...
2023/02/09 09:22:09 Job still running ...
2023/02/09 09:22:39 Job still running ...
2023/02/09 09:23:09 Job still running ...
2023/02/09 09:23:39 Job still running ...
2023/02/09 09:24:09 Job still running ...
2023/02/09 09:24:40 Job still running ...
2023/02/09 09:25:10 Job still running ...
2023/02/09 09:25:40 Job still running ...
2023/02/09 09:26:10 Job still running ...
2023/02/09 09:26:40 Job still running ...
2023/02/09 09:27:10 Job still running ...
2023/02/09 09:27:40 Job still running ...
2023/02/09 09:28:10 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-09_01_19_08-7730121794154403315 failed
--- FAIL: TestXLang_Partition (580.15s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3322.591s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675931601104729043
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45385 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@PdQGBxzYSu" is_bounded:BOUNDED windowing_strategy_id:"w0@PdQGBxzYSu"}} windowing_strategies:{key:"w0@PdQGBxzYSu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@PdQGBxzYSu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@PdQGBxzYSu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@PdQGBxzYSu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675931601104729043\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"PdQGBxzYSu"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45385 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@PdQGBxzYSu" is_bounded:BOUNDED windowing_strategy_id:"w0@PdQGBxzYSu"}} windowing_strategies:{key:"w0@PdQGBxzYSu" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@PdQGBxzYSu" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@PdQGBxzYSu" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@PdQGBxzYSu" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675931601104729043\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"PdQGBxzYSu"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 42 [running]:
testing.tRunner.func1.2({0xf66740, 0xc00050d780})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66740, 0xc00050d780})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000116e20?, 0xc000509680?}, {0x1130948, 0x39}, {0xc0000ee0c0?, 0xa97ee0?, 0x1?}, {0xc00011cf40, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000116dc0?, 0xc000509680?}, {0xc0001425a0, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0x7ff96892f448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011cf40, 0xf}, {0xc0001425a0, 0x52}, {0xeb4b60, 0xc0000427d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0005236c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0005236c0, 0x11627a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.370s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1845bbfee2a5672d5d39194133ad9b34f67eb61b3ce95223cd03bc71f7c24ec8
  Associated tags:
 - 20230209-083245
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-083245
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-083245].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1845bbfee2a5672d5d39194133ad9b34f67eb61b3ce95223cd03bc71f7c24ec8].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3043034169cc95faa51fb4b7f90795470d30182f38ade14a62240343b0c1f191]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3043034169cc95faa51fb4b7f90795470d30182f38ade14a62240343b0c1f191])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3043034169cc95faa51fb4b7f90795470d30182f38ade14a62240343b0c1f191
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3043034169cc95faa51fb4b7f90795470d30182f38ade14a62240343b0c1f191].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68495dadcd3f9ed9a198294456ec59c923109e7bc0908ab640fad5e55caefc3e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68495dadcd3f9ed9a198294456ec59c923109e7bc0908ab640fad5e55caefc3e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68495dadcd3f9ed9a198294456ec59c923109e7bc0908ab640fad5e55caefc3e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68495dadcd3f9ed9a198294456ec59c923109e7bc0908ab640fad5e55caefc3e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 20s
216 actionable tasks: 162 executed, 42 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1268

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1268/display/redirect?page=changes>

Changes:

[noreply] Support batching as config in RunInference (sklearn and pytorch)

[noreply] Add a note on increased lower bounds. (#25389)

[noreply] Support samza portable UDF metrics. (#25265)


------------------------------------------
[...truncated 1013.74 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28254/go-8-1675912767051288867/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-023307"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209022048"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-023307"
      }
    ]
  },
  "name": "go-testxlang_partition-776",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/09 03:19:37 Submitted job: 2023-02-08_19_19_36-9706945947283704956
2023/02/09 03:19:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-08_19_19_36-9706945947283704956?project=apache-beam-testing
2023/02/09 03:19:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-08_19_19_36-9706945947283704956
2023/02/09 03:19:37 Job state: JOB_STATE_PENDING ...
2023/02/09 03:20:07 Job still running ...
2023/02/09 03:20:37 Job still running ...
2023/02/09 03:21:07 Job still running ...
2023/02/09 03:21:37 Job still running ...
2023/02/09 03:22:07 Job still running ...
2023/02/09 03:22:37 Job still running ...
2023/02/09 03:23:07 Job still running ...
2023/02/09 03:23:40 Job still running ...
2023/02/09 03:24:11 Job still running ...
2023/02/09 03:24:44 Job still running ...
2023/02/09 03:25:14 Job still running ...
2023/02/09 03:25:44 Job still running ...
2023/02/09 03:26:14 Job still running ...
2023/02/09 03:26:44 Job still running ...
2023/02/09 03:27:14 Job still running ...
2023/02/09 03:27:44 Job still running ...
2023/02/09 03:28:14 Job still running ...
2023/02/09 03:28:44 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-08_19_19_36-9706945947283704956 failed
--- FAIL: TestXLang_Partition (588.10s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3332.313s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675910025994757693
--- FAIL: TestBigQueryIO_BasicWriteRead (4.62s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38515 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NIzDYUgmQp" is_bounded:BOUNDED windowing_strategy_id:"w0@NIzDYUgmQp"}} windowing_strategies:{key:"w0@NIzDYUgmQp" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NIzDYUgmQp" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NIzDYUgmQp" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NIzDYUgmQp" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675910025994757693\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NIzDYUgmQp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38515 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@NIzDYUgmQp" is_bounded:BOUNDED windowing_strategy_id:"w0@NIzDYUgmQp"}} windowing_strategies:{key:"w0@NIzDYUgmQp" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@NIzDYUgmQp" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@NIzDYUgmQp" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@NIzDYUgmQp" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675910025994757693\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"NIzDYUgmQp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf66740, 0xc0005dbcc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66740, 0xc0005dbcc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a64a0?, 0xc0000b8050?}, {0x1130948, 0x39}, {0xc0005fc000?, 0xa97ee0?, 0x1?}, {0xc000126d10, 0xf}, 0xc000173d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6440?, 0xc0000b8050?}, {0xc00004c600, 0x52}, {0x1?}, {0xc000173ea8, 0x2, 0xe73b40?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000126d10, 0xf}, {0xc00004c600, 0x52}, {0xeb4b60, 0xc0000421c8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x11627a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.654s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b15b0b62607b49b850a3991666d8047ce188d6ef78e48f55494234b2bb44ae5b
  Associated tags:
 - 20230209-023307
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-023307
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230209-023307].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b15b0b62607b49b850a3991666d8047ce188d6ef78e48f55494234b2bb44ae5b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b85921cef70fd8d67b61d270c3edfeec60bfa78455f711572b635eeb986f4db]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230209022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b85921cef70fd8d67b61d270c3edfeec60bfa78455f711572b635eeb986f4db])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b85921cef70fd8d67b61d270c3edfeec60bfa78455f711572b635eeb986f4db
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6b85921cef70fd8d67b61d270c3edfeec60bfa78455f711572b635eeb986f4db].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2a766cc39d126b737274a2fd6552f2222b7c60133f7627c09eeb6339034fbd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230209022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2a766cc39d126b737274a2fd6552f2222b7c60133f7627c09eeb6339034fbd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2a766cc39d126b737274a2fd6552f2222b7c60133f7627c09eeb6339034fbd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0f2a766cc39d126b737274a2fd6552f2222b7c60133f7627c09eeb6339034fbd].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 52s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1267

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1267/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Minor updates to typescript generation.

[noreply] Add TensorRT runinference example for Text Classification (#25226)

[noreply] Bump cryptography from 39.0.0 to 39.0.1 in /sdks/python/container/py39

[noreply] Playground Frontend Test workflow (#24728) (#25254)

[noreply] Simpify composite literal in metrics_test.go (#25384)

[noreply] Replace use of deprecated strings.Title function (#25385)

[noreply] Explicitly set mongo container version for testing (#25369)

[noreply] Update upper bound for numpy. (#24725)


------------------------------------------
[...truncated 1017.61 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3601/go-8-1675891464053325990/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-203656"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208202047"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-203656"
      }
    ]
  },
  "name": "go-testxlang_partition-631",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/08 21:24:32 Submitted job: 2023-02-08_13_24_31-16246865553978896730
2023/02/08 21:24:32 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-08_13_24_31-16246865553978896730?project=apache-beam-testing
2023/02/08 21:24:32 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-08_13_24_31-16246865553978896730
2023/02/08 21:24:32 Job state: JOB_STATE_PENDING ...
2023/02/08 21:25:02 Job still running ...
2023/02/08 21:25:32 Job still running ...
2023/02/08 21:26:02 Job still running ...
2023/02/08 21:26:32 Job still running ...
2023/02/08 21:27:02 Job still running ...
2023/02/08 21:27:32 Job still running ...
2023/02/08 21:28:02 Job still running ...
2023/02/08 21:28:32 Job still running ...
2023/02/08 21:29:02 Job still running ...
2023/02/08 21:29:32 Job still running ...
2023/02/08 21:30:02 Job still running ...
2023/02/08 21:30:32 Job still running ...
2023/02/08 21:31:02 Job still running ...
2023/02/08 21:31:32 Job still running ...
2023/02/08 21:32:02 Job still running ...
2023/02/08 21:32:33 Job still running ...
2023/02/08 21:33:03 Job still running ...
2023/02/08 21:33:33 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-08_13_24_31-16246865553978896730 failed
--- FAIL: TestXLang_Partition (579.33s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3338.102s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675888709730934662
--- FAIL: TestBigQueryIO_BasicWriteRead (7.22s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42541 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ensROBssfF" is_bounded:BOUNDED windowing_strategy_id:"w0@ensROBssfF"}} windowing_strategies:{key:"w0@ensROBssfF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ensROBssfF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ensROBssfF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ensROBssfF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675888709730934662\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ensROBssfF"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42541 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ensROBssfF" is_bounded:BOUNDED windowing_strategy_id:"w0@ensROBssfF"}} windowing_strategies:{key:"w0@ensROBssfF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ensROBssfF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ensROBssfF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ensROBssfF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675888709730934662\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ensROBssfF"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 21 [running]:
testing.tRunner.func1.2({0xf66740, 0xc0006e2740})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf66740, 0xc0006e2740})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010ea40?, 0xc0000bc460?}, {0x1130948, 0x39}, {0xc0000f00c0?, 0xa97ee0?, 0x1?}, {0xc000043cc0, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010e9e0?, 0xc0000bc460?}, {0xc00054a300, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0x7f6221f20aa8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043cc0, 0xf}, {0xc00054a300, 0x52}, {0xeb4b60, 0xc000128410})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102ea0, 0x11627a0)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	10.257s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.046s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.051s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.064s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7e0ccdb9105af3dd7bb9a2d121b8e8ec103873013dbdd41be96601bd84f833b6
  Associated tags:
 - 20230208-203656
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-203656
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-203656].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7e0ccdb9105af3dd7bb9a2d121b8e8ec103873013dbdd41be96601bd84f833b6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208202047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:37c7ba688f2b1c8bcce107b5d10c4e4ad5fe60a6ed59c5ae3325d377a5091944]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208202047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:37c7ba688f2b1c8bcce107b5d10c4e4ad5fe60a6ed59c5ae3325d377a5091944])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:37c7ba688f2b1c8bcce107b5d10c4e4ad5fe60a6ed59c5ae3325d377a5091944
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:37c7ba688f2b1c8bcce107b5d10c4e4ad5fe60a6ed59c5ae3325d377a5091944].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208202047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2662667f1efe7c8d53ccd46aca373261cde70966b6cbc3bdb1607962b893e3fb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208202047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2662667f1efe7c8d53ccd46aca373261cde70966b6cbc3bdb1607962b893e3fb])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2662667f1efe7c8d53ccd46aca373261cde70966b6cbc3bdb1607962b893e3fb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2662667f1efe7c8d53ccd46aca373261cde70966b6cbc3bdb1607962b893e3fb].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 13m 44s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1266

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1266/display/redirect?page=changes>

Changes:

[noreply] [Spark runner] Removal of Spark 2 runner support (closes #25259)


------------------------------------------
[...truncated 589.71 KB...]
2023/02/08 15:25:30 Job still running ...
2023/02/08 15:26:00 Job still running ...
2023/02/08 15:26:30 Job still running ...
2023/02/08 15:27:00 Job still running ...
2023/02/08 15:27:30 Job still running ...
2023/02/08 15:28:01 Job still running ...
2023/02/08 15:28:31 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-08_07_19_29-7584392525883401798 failed
--- FAIL: TestXLang_Partition (580.64s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3322.978s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675866821502236891
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42987 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KhAlXMJrda" is_bounded:BOUNDED windowing_strategy_id:"w0@KhAlXMJrda"}} windowing_strategies:{key:"w0@KhAlXMJrda" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KhAlXMJrda" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KhAlXMJrda" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KhAlXMJrda" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675866821502236891\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KhAlXMJrda"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42987 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KhAlXMJrda" is_bounded:BOUNDED windowing_strategy_id:"w0@KhAlXMJrda"}} windowing_strategies:{key:"w0@KhAlXMJrda" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KhAlXMJrda" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KhAlXMJrda" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KhAlXMJrda" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675866821502236891\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KhAlXMJrda"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 15 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00048c840})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00048c840})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048a660?, 0xc0000bc280?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc0001311c0, 0xf}, 0xc000759d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048a600?, 0xc0000bc280?}, {0xc00004cd80, 0x52}, {0x1?}, {0xc000759ea8, 0x2, 0x7f9febc24b10?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001311c0, 0xf}, {0xc00004cd80, 0x52}, {0xe96fa0, 0xc0004821e0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103ba0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.297s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-143305
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-143305
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9980c1d74948d098d57e4dabcb15e4cb91a1af58f79cd07d8a452f8e8b2e33e
Deleted: sha256:559b7f9da51069cbc8bb39a5962cc86f03b9a1507c1d1a6e37930423b36032d1
Deleted: sha256:1796e2b3d145d442f1a30f788de4a7ee36081d8cbddaed072c2c7b448475a0a7
Deleted: sha256:5de27994c4b92510d31dd807cf3199528fff5de8c57dbae6b4a9af70f1d08f8d
Deleted: sha256:0cb48670d3d0b2e0dc2234c8270c2061638ae782b97f84441fce64cbc088c668
Deleted: sha256:2c65c2dd992829b419413181ad2f5e13806b87c41864ca000e11072c7827fe22
Deleted: sha256:2b841bac8e1942ec68275d0b5c966054f6d6559f9d47b9bf6f43de2ecc5a2c40
Deleted: sha256:3e1afe19c08d9d2ae9c69aea6563951e18c3774323cfeccc3905adfaec0600f1
Deleted: sha256:58362cd81d222c5d04ebee80916c6ccaa7190660b830dd55071f2f492ba4151d
Deleted: sha256:ab696dda937cb6b5b7f35ff1728cd8d56a2d7bbca704ac8d76ec1ff581f8c5b8
Deleted: sha256:8d803e777e5942648f1b7671906b71e3694c7bb3be167ff8a83882cee0d5ac4f
Deleted: sha256:ed56824bbf62c2fc522a1ca3b6d4980b73dc910d3be631a92329cf28c17b72a3
Deleted: sha256:3b71c6ebf81d37261e2e085ab658eb139f1b2fe687063720ce177b5111ec209c
Deleted: sha256:51737c4be6aff880e36d04037a121599e6a70401893ac9e277645a0306ea61d3
Deleted: sha256:64e9936687473b418488bb3856e1f344a7b4323b73b876b84c19acccee766667
Deleted: sha256:d5d1feb8007405cd5f32fde28f71cd3b1845b7ba512db0fb75d28cc7eb5333f9
Deleted: sha256:5ae07b58217c1197885dee2f3fb85bc295080357a306c19e096557e1447a0746
Deleted: sha256:5f554ad681bdfd9b01346db4db1333cb8c5be1dab46b8d1769c08ca691bd553a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-143305
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9980c1d74948d098d57e4dabcb15e4cb91a1af58f79cd07d8a452f8e8b2e33e
  Associated tags:
 - 20230208-143305
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-143305
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-143305].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f9980c1d74948d098d57e4dabcb15e4cb91a1af58f79cd07d8a452f8e8b2e33e].
$ rm -rf /tmp/tmp.Uc8r7oO9TT
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:39e79efe06591bca72b8893579074cb885d5840c57e9fb692db97e56ced37b93].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c
Deleted: sha256:33fd3dfc380d70b8a8cf16171878909a2a4ae2f96865c1360647622bf8568e05
Deleted: sha256:0a329855a206722613fbb8c7f59141636a4f8a683783648607a19952c41a22da
Deleted: sha256:b2c0c0ab68a886800cd2b2dc8150ea8427387a5c6354aed2642401276eecf734
Deleted: sha256:dd54af099174affef3ec771040c3a473eba5f70e5a6b67c842ebd1b8126831e7
Deleted: sha256:8fd7403a3bea06759a78da31c2b5c9f391cf555186bf5dfa4a3085d2d2ad5588
Deleted: sha256:d7be5f0c453f85af690f753da00d2ea57f6542b0064f01cdb4174c1c3f8ed9e8
Deleted: sha256:0fc06d52d82c84b8ddfa3efdcaa7d3b7220a1e7ce04689b49e6ac0147a943e90
Deleted: sha256:6c653a2466c5a481e618b49f29c26c57f8beb06be46371879995c16680547174
Deleted: sha256:152dcbc733eb20bd9d1c0c44a0730e27e2f0a632f70ccc9815577a73d780116b
Deleted: sha256:64a44e8369bdffd720c21068ed9fe543c703b7719f1453b2f63fb9385662b18a
Deleted: sha256:ca547c33fe286df26328872e3a3af571a0e50b5c371c5976aa89b08acfe1ec94
Deleted: sha256:ce22326ae79c4fa9673a20d517cc8209ab98e49e2f303dd40c057c258231e360
Deleted: sha256:7c822e6467ca733fac64a8514c0e6ab3234b5a7fea8298bbe40f9f96393e7db5
Deleted: sha256:417a45319620817e3c9b1a14d1dff6161b38a33227e81df45e177a36f2115649
Deleted: sha256:70e3d7168af235af7eca07cbd14bab32b36fc7a5cc215b794e5f7325fa4299ac
Deleted: sha256:5da495ad6550ae177bd9095fd102fdc2911cc60c9274818757fdaaafda508a05
Deleted: sha256:46489f4b8376882a11e7dde2e9840d477623e0d09c522856cf657ae99346ef0f
Deleted: sha256:e792a3c37e6fb14967bc6ba5c35cafb1a44cd1d0b8c8e6dd50e4cb7c2ba1ffef
Deleted: sha256:a35c81e0f05cedbd855ae394e192fa3629fb347ec3625966bb33cf3b83a5122a
Deleted: sha256:9a6eaecc00585c3d51baa65e036434ea9e98d2500937296ab017e8a669354131
Deleted: sha256:cb1be1edd18d0cc18125f02925bab3bd72c5dd933cd6d55c0f8f16f8f53cd782
Deleted: sha256:6462e3c35b72495793798a0bd8e5cd3ae0241301e208149637bb0a14fa210d49
Deleted: sha256:23a86ca0a396757a7634f9a372019e22281958f00607e00acaddcf34ff4ed7ef
Deleted: sha256:14d5148d583b4e3b6c33afee77e2804dc52f1a2d5a54e65c96e6df4a5aa3d696
Deleted: sha256:6de84444b40c544b0d538807a5eb13b9914033e8f6e7752cb797bd6930134442
Deleted: sha256:735c3f06b9b9464b19b69987b43b1b6684fbad698714af0e873248c472f123d6
Deleted: sha256:f810ad08f3923aa4c4cdf4045fc586045b7ccfd2f334cc3fe02bd30a209448d0
Deleted: sha256:e16fc14b084b08f9c810a6d29b515234db2876ed17c896d15750c5d47ecb42fb
Deleted: sha256:771503fdf1b306f2e419b4a0c52999f2e2f4c8bf0ddd7429f4f9f8f79cb41cce
Deleted: sha256:3df5b7357d37d13da16b0ca9620c25ad454485028fe1d174cedd3f907c1269d8
Deleted: sha256:a419d782976cecb88213dd70cbb1eb6b0dc8a6251262b7c31be971e5bfd1bed3
Deleted: sha256:3041f32fe48b7d877100a7d3b4cf8b0176b389b0a3f027a9c5cc12b71427ac6b
Deleted: sha256:a44c899cda58eb3892beeefe0f6ff971402460eae391466703c59eb88dd28146
Deleted: sha256:ddfbeb4a2f1c1d178c8bdc952f17fc53944e956177fc97df89a4be32cd61539f
Deleted: sha256:db92a683a36c947cac1a23ca25eb3ab7d52a94a537d288e4530bb66f84aa4ca3
Deleted: sha256:1c6d40486a57723967b5c18e504cbf240407bfb77e3d99bfc98a601f1bfe6b3a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:82fc9cc31a953b82e55f029041040e6751d16541b2190f8cd8118afd4ac8bc7c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 450722.
Stopping expansion service pid: 450723.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 43s
216 actionable tasks: 172 executed, 34 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1265

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1265/display/redirect>

Changes:


------------------------------------------
[...truncated 1010.96 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test13252/go-8-1675848042895200823/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-083523"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208082125"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-083523"
      }
    ]
  },
  "name": "go-testxlang_partition-863",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/08 09:20:51 Submitted job: 2023-02-08_01_20_50-15118606719539216185
2023/02/08 09:20:51 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-08_01_20_50-15118606719539216185?project=apache-beam-testing
2023/02/08 09:20:51 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-08_01_20_50-15118606719539216185
2023/02/08 09:20:51 Job state: JOB_STATE_PENDING ...
2023/02/08 09:21:21 Job still running ...
2023/02/08 09:21:51 Job still running ...
2023/02/08 09:22:21 Job still running ...
2023/02/08 09:22:51 Job still running ...
2023/02/08 09:23:21 Job still running ...
2023/02/08 09:23:51 Job still running ...
2023/02/08 09:24:21 Job still running ...
2023/02/08 09:24:51 Job still running ...
2023/02/08 09:25:22 Job still running ...
2023/02/08 09:25:52 Job still running ...
2023/02/08 09:26:22 Job still running ...
2023/02/08 09:26:52 Job still running ...
2023/02/08 09:27:22 Job still running ...
2023/02/08 09:27:52 Job still running ...
2023/02/08 09:28:22 Job still running ...
2023/02/08 09:28:52 Job still running ...
2023/02/08 09:29:22 Job still running ...
2023/02/08 09:29:52 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-08_01_20_50-15118606719539216185 failed
--- FAIL: TestXLang_Partition (579.80s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3262.518s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675845363327853266
--- FAIL: TestBigQueryIO_BasicWriteRead (4.99s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39731 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xZrYNENwKH" is_bounded:BOUNDED windowing_strategy_id:"w0@xZrYNENwKH"}} windowing_strategies:{key:"w0@xZrYNENwKH" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xZrYNENwKH" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xZrYNENwKH" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xZrYNENwKH" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675845363327853266\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xZrYNENwKH"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39731 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xZrYNENwKH" is_bounded:BOUNDED windowing_strategy_id:"w0@xZrYNENwKH"}} windowing_strategies:{key:"w0@xZrYNENwKH" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xZrYNENwKH" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xZrYNENwKH" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xZrYNENwKH" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675845363327853266\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xZrYNENwKH"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00017fd40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00017fd40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a64e0?, 0xc0006a0050?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc000042df0, 0xf}, 0xc00056dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6480?, 0xc0006a0050?}, {0xc00051a300, 0x52}, {0x1?}, {0xc00056dea8, 0x2, 0x7f3a6471dc58?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042df0, 0xf}, {0xc00051a300, 0x52}, {0xe96fa0, 0xc0003f20d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000d29c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000d29c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.025s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.041s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d54d26e9b358d9b314cae77bafe6cdd8a3ac93307652b926388425e244b87a5
  Associated tags:
 - 20230208-083523
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-083523
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-083523].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3d54d26e9b358d9b314cae77bafe6cdd8a3ac93307652b926388425e244b87a5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208082125]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a2fc7a3fbb6ca3c325f3c8d4a6350486ebee691e275e6a99d9d15b24f44e5ade]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208082125] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a2fc7a3fbb6ca3c325f3c8d4a6350486ebee691e275e6a99d9d15b24f44e5ade])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a2fc7a3fbb6ca3c325f3c8d4a6350486ebee691e275e6a99d9d15b24f44e5ade
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a2fc7a3fbb6ca3c325f3c8d4a6350486ebee691e275e6a99d9d15b24f44e5ade].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208082125]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:73e36e56c0fa07e59c0daa5a7087ba8b8b2bbd43b474b03d939907ad573d64ac]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208082125] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:73e36e56c0fa07e59c0daa5a7087ba8b8b2bbd43b474b03d939907ad573d64ac])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:73e36e56c0fa07e59c0daa5a7087ba8b8b2bbd43b474b03d939907ad573d64ac
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:73e36e56c0fa07e59c0daa5a7087ba8b8b2bbd43b474b03d939907ad573d64ac].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 42s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1264

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1264/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Better batching for higher fixed costs.

[Robert Bradshaw] Add an option to get the old behavior.

[Robert Bradshaw] lint

[noreply] [BEAM-12164] Enforced only positive state transitions from CREATED ->

[noreply] Added Role-based access control integration tests for Spanner Change

[noreply] Fail the pipeline when a mismatched Python or Beam version is detected.


------------------------------------------
[...truncated 1015.88 KB...]
    "workerPools": [
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18469/go-8-1675826460509124575/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-023410"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208022050"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-023410"
      }
    ]
  },
  "name": "go-testxlang_partition-380",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/08 03:21:09 Submitted job: 2023-02-07_19_21_09-2114269845368830387
2023/02/08 03:21:09 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-07_19_21_09-2114269845368830387?project=apache-beam-testing
2023/02/08 03:21:09 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-07_19_21_09-2114269845368830387
2023/02/08 03:21:10 Job state: JOB_STATE_PENDING ...
2023/02/08 03:21:40 Job still running ...
2023/02/08 03:22:10 Job still running ...
2023/02/08 03:22:40 Job still running ...
2023/02/08 03:23:10 Job still running ...
2023/02/08 03:23:40 Job still running ...
2023/02/08 03:24:10 Job still running ...
2023/02/08 03:24:40 Job still running ...
2023/02/08 03:25:10 Job still running ...
2023/02/08 03:25:40 Job still running ...
2023/02/08 03:26:10 Job still running ...
2023/02/08 03:26:40 Job still running ...
2023/02/08 03:27:10 Job still running ...
2023/02/08 03:27:40 Job still running ...
2023/02/08 03:28:10 Job still running ...
2023/02/08 03:28:40 Job still running ...
2023/02/08 03:29:10 Job still running ...
2023/02/08 03:29:40 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-07_19_21_09-2114269845368830387 failed
--- FAIL: TestXLang_Partition (550.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3325.283s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675823690286879137
--- FAIL: TestBigQueryIO_BasicWriteRead (5.50s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43237 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@hTExkbQwuo" is_bounded:BOUNDED windowing_strategy_id:"w0@hTExkbQwuo"}} windowing_strategies:{key:"w0@hTExkbQwuo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@hTExkbQwuo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@hTExkbQwuo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@hTExkbQwuo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675823690286879137\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"hTExkbQwuo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43237 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@hTExkbQwuo" is_bounded:BOUNDED windowing_strategy_id:"w0@hTExkbQwuo"}} windowing_strategies:{key:"w0@hTExkbQwuo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@hTExkbQwuo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@hTExkbQwuo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@hTExkbQwuo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675823690286879137\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"hTExkbQwuo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 10 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000035340})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000035340})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001e04c0?, 0xc0001b0230?}, {0x110f943, 0x39}, {0xc0004e20c0?, 0xa969c0?, 0x1?}, {0xc000133a70, 0xf}, 0xc000143d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0001e0320?, 0xc0001b0230?}, {0xc000180c00, 0x52}, {0x1?}, {0xc000143ea8, 0x2, 0x7ff4ea38f448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000133a70, 0xf}, {0xc000180c00, 0x52}, {0xe96fa0, 0xc000042130})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004ca000)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004ca000, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.536s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.035s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:754b5b7b2ed395952323693c930eb055126cfe4e04551a9fc1f0b0e43f8ad98b
  Associated tags:
 - 20230208-023410
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-023410
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230208-023410].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:754b5b7b2ed395952323693c930eb055126cfe4e04551a9fc1f0b0e43f8ad98b].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208022050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:784dba78454e4512d15eccb4a83f30a9c016e5bd13da3c28b455ad22d6cf8e17]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230208022050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:784dba78454e4512d15eccb4a83f30a9c016e5bd13da3c28b455ad22d6cf8e17])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:784dba78454e4512d15eccb4a83f30a9c016e5bd13da3c28b455ad22d6cf8e17
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:784dba78454e4512d15eccb4a83f30a9c016e5bd13da3c28b455ad22d6cf8e17].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208022050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f765999a690dd7bacd2871f46be6d1d0901e536f659f4ace26e2cb9c390d039]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230208022050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f765999a690dd7bacd2871f46be6d1d0901e536f659f4ace26e2cb9c390d039])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f765999a690dd7bacd2871f46be6d1d0901e536f659f4ace26e2cb9c390d039
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2f765999a690dd7bacd2871f46be6d1d0901e536f659f4ace26e2cb9c390d039].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 49s
216 actionable tasks: 145 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1263

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1263/display/redirect>

Changes:


------------------------------------------
[...truncated 1018.59 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test18615/go-8-1675805135271261258/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207202045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311"
      }
    ]
  },
  "name": "go-testxlang_partition-820",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/07 21:26:17 Submitted job: 2023-02-07_13_26_17-9744540441439090562
2023/02/07 21:26:17 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-07_13_26_17-9744540441439090562?project=apache-beam-testing
2023/02/07 21:26:17 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-07_13_26_17-9744540441439090562
2023/02/07 21:26:17 Job state: JOB_STATE_PENDING ...
2023/02/07 21:26:47 Job still running ...
2023/02/07 21:27:17 Job still running ...
2023/02/07 21:27:47 Job still running ...
2023/02/07 21:28:17 Job still running ...
2023/02/07 21:28:47 Job still running ...
2023/02/07 21:29:17 Job still running ...
2023/02/07 21:29:48 Job still running ...
2023/02/07 21:30:18 Job still running ...
2023/02/07 21:30:48 Job still running ...
2023/02/07 21:31:18 Job still running ...
2023/02/07 21:31:48 Job still running ...
2023/02/07 21:32:18 Job still running ...
2023/02/07 21:32:48 Job still running ...
2023/02/07 21:33:18 Job still running ...
2023/02/07 21:33:48 Job still running ...
2023/02/07 21:34:18 Job still running ...
2023/02/07 21:34:48 Job still running ...
2023/02/07 21:35:18 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-07_13_26_17-9744540441439090562 failed
--- FAIL: TestXLang_Partition (613.56s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3704.384s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675802048734592840
--- FAIL: TestBigQueryIO_BasicWriteRead (5.77s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34721 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@DXZpFqacIK" is_bounded:BOUNDED windowing_strategy_id:"w0@DXZpFqacIK"}} windowing_strategies:{key:"w0@DXZpFqacIK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@DXZpFqacIK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@DXZpFqacIK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@DXZpFqacIK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675802048734592840\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"DXZpFqacIK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34721 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@DXZpFqacIK" is_bounded:BOUNDED windowing_strategy_id:"w0@DXZpFqacIK"}} windowing_strategies:{key:"w0@DXZpFqacIK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@DXZpFqacIK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@DXZpFqacIK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@DXZpFqacIK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675802048734592840\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"DXZpFqacIK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0004ff600})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0004ff600})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0005a0880?, 0xc000590230?}, {0x110f943, 0x39}, {0xc0005560c0?, 0xa969c0?, 0x1?}, {0xc00048aea0, 0xf}, 0xc000177d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0005a0820?, 0xc000590230?}, {0xc0005b4480, 0x52}, {0x1?}, {0xc000177ea8, 0x2, 0x7fde7834c0f0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048aea0, 0xf}, {0xc0005b4480, 0x52}, {0xe96fa0, 0xc0005a4780})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103d40)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103d40, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.811s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.042s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.058s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aa865b44c87c6d6b68ac035fcd5331488728d0df809bd044f0b734e994c9180f
Deleted: sha256:78ff0bc4345e2defecb9ad06c289125e1a66b94ad75d3f652cca408669a782fb
Deleted: sha256:a16adf09d90f40dc5ed91dec92cc6ef2b3c7ddaf921a402d85e677c85f3a5f70
Deleted: sha256:11d58bbdf077135f4d1fd5325895a9ab25bb8669cee225b1bef75f4b40b2a065
Deleted: sha256:0009856bc5ea35fbd63752957e57307fedbb13af53614f65f5e63a0c96b0eb9f
Deleted: sha256:4de27ca7a36039f477746e08157ebcb0d9fee187183cc0fa0190759687cd16d4
Deleted: sha256:a022a0cd0823bfc8db1148b58830e7059c0d5d9592d64c4b87464f3429e7e679
Deleted: sha256:85cf8f241cfb77e0eee1d96b71ff37d6f71f6f9246bc1be05b66ac9fc2f6f859
Deleted: sha256:47fe8f2948dc72cda26538c7357bcb72fa59fbcd8fd826be3074527303ddd2f7
Deleted: sha256:30517b52e37ecc3d4a9c97e813cbce3ea5239157f63a0ca5a9e4b43c66b51c65
Deleted: sha256:76ab4509d1eca2e67b6458abf195c6c33e304b0e5633f16a00be571cc0886a43
Deleted: sha256:2e288633856dce3d645d8026202c627b66734a9f491a814364a7660606341272
Deleted: sha256:49fda7284cf6f879c5c9e04e90f8841573bc1364f29cdbc8abd87890b3e79ad5
Deleted: sha256:2038dc0857391b05dd5e5b530cf50b205fdd28b754a9992192a43ee3437dcd8f
Deleted: sha256:fe3a65d132eb503fedff6417df35b0d9c2d316fd33931eb017bc7c9123de74c6
Deleted: sha256:e3a2bacd90ffea5ef58fa683b0b165f568cbcd178359a829778b4613f12ab9e3
Deleted: sha256:576e4105cb7c28d15aa831f3fa517208d645768713e15809ffc26c8e8620d651
Deleted: sha256:0fa6dbd24941ad9722707cbb3dff3b7deab301a2ed7651d29ea7c2a5742a85d8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aa865b44c87c6d6b68ac035fcd5331488728d0df809bd044f0b734e994c9180f
  Associated tags:
 - 20230207-203311
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-203311].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aa865b44c87c6d6b68ac035fcd5331488728d0df809bd044f0b734e994c9180f].
$ rm -rf /tmp/tmp.T4eAIwe7NO
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:262815eafebf23890aae228075fc8719027a439a3c70cb44c39ad688c4c44e6c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207202045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207202045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207202045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b3455576ea71f3a00403752227ef60c7d3061a8f9438a3c38c68300f2a72b1c5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3838547.
Stopping expansion service pid: 3838548.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 15m 29s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1262

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1262/display/redirect>

Changes:


------------------------------------------
[...truncated 1009.92 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32386/go-8-1675783106633787526/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207142045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235"
      }
    ]
  },
  "name": "go-testxlang_partition-993",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/07 15:18:35 Submitted job: 2023-02-07_07_18_34-13483765930888226977
2023/02/07 15:18:35 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-07_07_18_34-13483765930888226977?project=apache-beam-testing
2023/02/07 15:18:35 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-07_07_18_34-13483765930888226977
2023/02/07 15:18:35 Job state: JOB_STATE_PENDING ...
2023/02/07 15:19:05 Job still running ...
2023/02/07 15:19:35 Job still running ...
2023/02/07 15:20:05 Job still running ...
2023/02/07 15:20:35 Job still running ...
2023/02/07 15:21:05 Job still running ...
2023/02/07 15:21:35 Job still running ...
2023/02/07 15:22:05 Job still running ...
2023/02/07 15:22:35 Job still running ...
2023/02/07 15:23:05 Job still running ...
2023/02/07 15:23:35 Job still running ...
2023/02/07 15:24:05 Job still running ...
2023/02/07 15:24:35 Job still running ...
2023/02/07 15:25:05 Job still running ...
2023/02/07 15:25:35 Job still running ...
2023/02/07 15:26:06 Job still running ...
2023/02/07 15:26:36 Job still running ...
2023/02/07 15:27:06 Job still running ...
2023/02/07 15:27:36 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-07_07_18_34-13483765930888226977 failed
--- FAIL: TestXLang_Partition (579.77s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3295.604s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675780395192611778
--- FAIL: TestBigQueryIO_BasicWriteRead (5.34s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35183 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qTjxQhNtEv" is_bounded:BOUNDED windowing_strategy_id:"w0@qTjxQhNtEv"}} windowing_strategies:{key:"w0@qTjxQhNtEv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qTjxQhNtEv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qTjxQhNtEv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qTjxQhNtEv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675780395192611778\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qTjxQhNtEv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:35183 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qTjxQhNtEv" is_bounded:BOUNDED windowing_strategy_id:"w0@qTjxQhNtEv"}} windowing_strategies:{key:"w0@qTjxQhNtEv" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qTjxQhNtEv" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qTjxQhNtEv" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qTjxQhNtEv" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675780395192611778\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qTjxQhNtEv"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 25 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000339fc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000339fc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00058e380?, 0xc0000ba140?}, {0x110f943, 0x39}, {0xc00015a180?, 0xa969c0?, 0x1?}, {0xc000042dd0, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00058e320?, 0xc0000ba140?}, {0xc000456360, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f19327be768?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042dd0, 0xf}, {0xc000456360, 0x52}, {0xe96fa0, 0xc0005900b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000d2ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000d2ea0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.372s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.051s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4cd0f7af63cdaf545bbdd320ada7963b2ac929f32beefd9992b4444048e92d2
Deleted: sha256:eb8996db838441f70490b748957aafab1a842e14caaeec4fc240db29aa5587f1
Deleted: sha256:3ccc72b2bf57f47572bc41bc879d619734b1cd55f1dcf1e881975cc19d4fea79
Deleted: sha256:d161e8ced986ffbc19e3f85f503f0d583f0ac5f5b96ce8284ca0de0acf534c34
Deleted: sha256:ad302a90f918e7302efbc7bf776417e153b56413f4970c22c4e7c130f53cb870
Deleted: sha256:61eee054da6d466da1d54fdfd1f344da4f0c35fcd618430ab606728bf2b8bb49
Deleted: sha256:cc114c90ec76683e9c921f4e0c17faca31b0f31d1dd5304cedae1dbdd84da7d6
Deleted: sha256:9d59f58d72cec9c02ffe932a6be3403d8608fc97e61fc6cc36f08b72a9e421ac
Deleted: sha256:a5c5f7b1205f540155c0893aab8f256ab5d7686f9fabc125e5d2e4705a2cee1f
Deleted: sha256:722262b176608266944c79bd89280641edd167ba06917fa161dabe4eb0552c84
Deleted: sha256:b3fc20e7f5c2fb3dbd0710ed8219050bf8c06467d4ec75331751ad908a1c100e
Deleted: sha256:6f188283e88651f04b336350e2f85481f3fca458523fa28e1918b2cd1f7b5117
Deleted: sha256:7a7f5162fd6ad284a3236f1161bcd2901ace1c735d94871fac541515633be227
Deleted: sha256:a9f5b83d08a239b6990c07e7dcb058763dbe66d9ed840c88d4a060017693e6dc
Deleted: sha256:cf9e68f9d952dfac9d91ab76b6363f201db7a1357c7d557b5ae4cf27956e445e
Deleted: sha256:ca12696e748804b021f2fc9d4f2f4177b4d8f8297b8c7dc32d83195580369413
Deleted: sha256:1ac63dbaf8c99f4b37cb06c4fa77be40d8bc8b03f61b79f4ab76eec6b9810a7d
Deleted: sha256:124d7a7659ee622b614697a84c215f9191edb982dc7f37f2d1f02318f4763834
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4cd0f7af63cdaf545bbdd320ada7963b2ac929f32beefd9992b4444048e92d2
  Associated tags:
 - 20230207-143235
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-143235].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:b4cd0f7af63cdaf545bbdd320ada7963b2ac929f32beefd9992b4444048e92d2].
$ rm -rf /tmp/tmp.UhmGrT7Cpo
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207142045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f1810616b4320c84a1047b97dbbb4512b967a11d235a934ba84c1671ecbf1c64].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207142045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ef2b6c79768a28e981ecaeeb3fc31e5f8f7c5c8c4f76d5e227365b8c1ed3f6b6].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 467944.
Stopping expansion service pid: 467945.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 47s
216 actionable tasks: 144 executed, 60 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1261

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1261/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10632/go-8-1675761520437997645/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207082050"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226"
      }
    ]
  },
  "name": "go-testxlang_partition-812",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/07 09:18:48 Submitted job: 2023-02-07_01_18_48-6088569915293965297
2023/02/07 09:18:48 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-07_01_18_48-6088569915293965297?project=apache-beam-testing
2023/02/07 09:18:48 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-07_01_18_48-6088569915293965297
2023/02/07 09:18:49 Job state: JOB_STATE_PENDING ...
2023/02/07 09:19:19 Job still running ...
2023/02/07 09:19:49 Job still running ...
2023/02/07 09:20:19 Job still running ...
2023/02/07 09:20:49 Job still running ...
2023/02/07 09:21:19 Job still running ...
2023/02/07 09:21:49 Job still running ...
2023/02/07 09:22:19 Job still running ...
2023/02/07 09:22:49 Job still running ...
2023/02/07 09:23:19 Job still running ...
2023/02/07 09:23:49 Job still running ...
2023/02/07 09:24:19 Job still running ...
2023/02/07 09:24:49 Job still running ...
2023/02/07 09:25:19 Job still running ...
2023/02/07 09:25:49 Job still running ...
2023/02/07 09:26:19 Job still running ...
2023/02/07 09:26:49 Job still running ...
2023/02/07 09:27:19 Job still running ...
2023/02/07 09:27:50 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-07_01_18_48-6088569915293965297 failed
--- FAIL: TestXLang_Partition (579.88s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3320.764s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675758782750206168
--- FAIL: TestBigQueryIO_BasicWriteRead (4.37s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39319 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@hnZWeZITmj" is_bounded:BOUNDED windowing_strategy_id:"w0@hnZWeZITmj"}} windowing_strategies:{key:"w0@hnZWeZITmj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@hnZWeZITmj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@hnZWeZITmj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@hnZWeZITmj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675758782750206168\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"hnZWeZITmj"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39319 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@hnZWeZITmj" is_bounded:BOUNDED windowing_strategy_id:"w0@hnZWeZITmj"}} windowing_strategies:{key:"w0@hnZWeZITmj" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@hnZWeZITmj" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@hnZWeZITmj" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@hnZWeZITmj" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675758782750206168\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"hnZWeZITmj"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 21 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000466380})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000466380})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7600?, 0xc0000d6a50?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc00012ab90, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a75a0?, 0xc0000d6a50?}, {0xc00052e300, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00012ab90, 0xf}, {0xc00052e300, 0x52}, {0xe96fa0, 0xc0003f8d98})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a6ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a6ea0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.406s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6fbc989891f14601a32ad8ae3cac6fd51f8dd12f4ee54f9c11a8d6aa745cf2c9
Deleted: sha256:8e12af547bb1708d3acafff6244b7113d86b57d3eba01c362aba7b0f35a4ccf8
Deleted: sha256:a0c243479450f2553031c0680c6a724d1871e2e546850afe3d5b32fd811e6de0
Deleted: sha256:ca3ba340c359a06cad3148944773bb2affbb8468bf16860f9d80e9cd99741491
Deleted: sha256:81819dc21d10a07b75cefb5ff694c2b7b5aa096fe7b2811f1393e805ecdcd9c6
Deleted: sha256:38464067968e3439f06b80f6ee779af047fbfb8669b1c606329dffd43788aaef
Deleted: sha256:e8db9dd0af08f3bff836c974b5b7bb79402ca95975b150f792ff45d59d959899
Deleted: sha256:72ba4a516f4701b70129f9bbdf5257bacff23e89ab9c528487229682e970937e
Deleted: sha256:9f6fe9ac71b58812f9a531446d9cec25e7cb02e226cdd6b435ea836d12f653e1
Deleted: sha256:5eb524694c8d70361e7936f4d967c35729ef8855d80eb3665b7d09b17abd0df6
Deleted: sha256:d152848970aa2baebb2b6b6578eb626f2d143aa20c526457fb4d43ed716513dc
Deleted: sha256:eded0e042761c41db235cd426c13d4acc5bd2f0134c9b2d654dff31328002abe
Deleted: sha256:fc3f7e13d75d55089d4b86e8c8e873fdef0f7722d45915ddf5ea3f6a1de45fea
Deleted: sha256:637b88e7052d7d650a760e507224bae3d023be85de9938efdf4818d1a7bddedd
Deleted: sha256:3b9cf4510c4d8e1a31aa43a3da64c90b730726f77c54323556adb5d3504ec17d
Deleted: sha256:65f4bd92d443b7e8073502cb103e4b47b80e507e620c947c08a2fa7cd928c8b2
Deleted: sha256:273be9749aee9d0a378cd4892a341dc7cea697083d262b2a20e5343106972c0d
Deleted: sha256:32518bedb3267f3e081ddd550bd277b7c7acddcaa224e727a6078a3b98d748bc
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6fbc989891f14601a32ad8ae3cac6fd51f8dd12f4ee54f9c11a8d6aa745cf2c9
  Associated tags:
 - 20230207-083226
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-083226].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:6fbc989891f14601a32ad8ae3cac6fd51f8dd12f4ee54f9c11a8d6aa745cf2c9].
$ rm -rf /tmp/tmp.PT2t9HCRMY
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:d0c856ea79882b68ed0e81504dd98823ae0ec20f4db2390801b077445f55c1f1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f4f321b44765ebce059c8eed2c93ca5f16bbb777ed4a2df6c6e84f867fff9187].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3296997.
Stopping expansion service pid: 3296998.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 56s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1260

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1260/display/redirect?page=changes>

Changes:

[noreply] Upgrading spring-expression to latest patch version (#25348)


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19227/go-8-1675739912586405430/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207022048"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247"
      }
    ]
  },
  "name": "go-testxlang_partition-911",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/07 03:18:42 Submitted job: 2023-02-06_19_18_40-16859317053906421281
2023/02/07 03:18:42 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-06_19_18_40-16859317053906421281?project=apache-beam-testing
2023/02/07 03:18:42 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-06_19_18_40-16859317053906421281
2023/02/07 03:18:42 Job state: JOB_STATE_PENDING ...
2023/02/07 03:19:12 Job still running ...
2023/02/07 03:19:42 Job still running ...
2023/02/07 03:20:12 Job still running ...
2023/02/07 03:20:42 Job still running ...
2023/02/07 03:21:12 Job still running ...
2023/02/07 03:21:42 Job still running ...
2023/02/07 03:22:12 Job still running ...
2023/02/07 03:22:42 Job still running ...
2023/02/07 03:23:12 Job still running ...
2023/02/07 03:23:42 Job still running ...
2023/02/07 03:24:12 Job still running ...
2023/02/07 03:24:42 Job still running ...
2023/02/07 03:25:13 Job still running ...
2023/02/07 03:25:43 Job still running ...
2023/02/07 03:26:13 Job still running ...
2023/02/07 03:26:43 Job still running ...
2023/02/07 03:27:13 Job still running ...
2023/02/07 03:27:43 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-06_19_18_40-16859317053906421281 failed
--- FAIL: TestXLang_Partition (581.00s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3292.994s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675737203760739584
--- FAIL: TestBigQueryIO_BasicWriteRead (4.70s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34211 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MLqCJMDHli" is_bounded:BOUNDED windowing_strategy_id:"w0@MLqCJMDHli"}} windowing_strategies:{key:"w0@MLqCJMDHli" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MLqCJMDHli" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MLqCJMDHli" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MLqCJMDHli" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675737203760739584\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MLqCJMDHli"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34211 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MLqCJMDHli" is_bounded:BOUNDED windowing_strategy_id:"w0@MLqCJMDHli"}} windowing_strategies:{key:"w0@MLqCJMDHli" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MLqCJMDHli" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MLqCJMDHli" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MLqCJMDHli" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675737203760739584\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MLqCJMDHli"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 52 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000112dc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000112dc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480900?, 0xc0004bf680?}, {0x110f943, 0x39}, {0xc0000ee0c0?, 0xa969c0?, 0x1?}, {0xc000118be0, 0xf}, 0xc0001a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004808a0?, 0xc0004bf680?}, {0xc0004d8300, 0x52}, {0x1?}, {0xc0001a9ea8, 0x2, 0x7fed9e443d50?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000118be0, 0xf}, {0xc0004d8300, 0x52}, {0xe96fa0, 0xc000119ef0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00048b040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00048b040, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.736s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09bf12e7378eb328268f4263d2e1049e89c7e5284154464948817058f01bf738
Deleted: sha256:538653277963aa34cbd2afed50a787a5beecd50184d16299ce048d84e83c28a9
Deleted: sha256:b269f93265fc71b7d8009d2e05793ceeb4c6bf0eec0c08c6cae554e14b929ec0
Deleted: sha256:74aaf72876378dbf07db214c3e7f65839cece7bdb28b155eb724d14879ae9332
Deleted: sha256:683bbfdf99da411ff675b370a29cb39d556607aa4cd79deef4073ec822703688
Deleted: sha256:b1a41366322ec0b32bdf2138a6e38792b05b861e69b378c645f744ad2993f0b1
Deleted: sha256:a4c07dfdbe8e838b455675cdfd468baf20a7f3b0d5ea343cd863b6598ad86188
Deleted: sha256:b85d22b28129347eede30d72762e1fc370c37a3e6cb8ed827c81be1286e0da2c
Deleted: sha256:3f5a1e97bdef26bc9256eca8b873138055f414ec9d00834807d48a471d0403b5
Deleted: sha256:52a9856d90fe47685f6a6ed3c74b17943edea5abbda78dd2439d1859186a05d2
Deleted: sha256:10e2670d512ba6980f7bd0b8b7682d3bef46dfc47e79616179f46d7593266600
Deleted: sha256:50a0cdabda5b867ba62ef7b10e39a32f6164dda5e057296b227d5ccdda8316dd
Deleted: sha256:3142874a7f053e890337ef545a83859a65e577491a3bbc152a215248b5c3ff76
Deleted: sha256:bb09e3801563ca95bfa04072c74bf7f23727770fa135b8630991eb0fd2636a4f
Deleted: sha256:4f9c2b01ca80026d67f5d24349953e981c1e365a17228c15f321ab74ad01be3d
Deleted: sha256:5a6dad883d659f619cde3b9990d752c5a6408ab7dfc5d2b25aaf71774a98cb54
Deleted: sha256:ec35b4a3040929599989ec0a995d753a424aa7c8ad38bba84baa8ff1348c95c6
Deleted: sha256:3be4a34dbde3816459e16712320851d99f39ab2c3537d16157383f4934b7e59c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09bf12e7378eb328268f4263d2e1049e89c7e5284154464948817058f01bf738
  Associated tags:
 - 20230207-023247
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230207-023247].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:09bf12e7378eb328268f4263d2e1049e89c7e5284154464948817058f01bf738].
$ rm -rf /tmp/tmp.7Kc25FlnCq
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207022048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230207022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:6e3a345a000c1e32004e1db89c660c169a1e59f38fcab0d5b37c776495d1fbae].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207022048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207022048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230207022048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:92765f88ddd5187cb9cda120004465d30b212c09a381b0d1b7a64d7362b5ae90].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3191839.
Stopping expansion service pid: 3191840.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 51s
216 actionable tasks: 156 executed, 48 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1259

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1259/display/redirect?page=changes>

Changes:

[Andrew Pilloud] Don't discard output column names

[noreply] Allow for setMaxRetryJobs in BigQueryIO to be configurable (#25224)

[noreply] delete file used in internal testing (#25339)

[noreply] Fix output timestamp for multi output receiver in FnApiDoFnRunner #25344

[noreply] Change UnboundedScheduledExecutorService to avoid creating threads when


------------------------------------------
[...truncated 589.04 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-8P-uUIFg0VQ9yTqhqxbGUhHRVFxLNksFtULEpYjIqnw.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test22922/go-8-1675718420907894005/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-203413"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206202044"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-203413"
      }
    ]
  },
  "name": "go-testxlang_partition-302",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/06 21:20:30 Submitted job: 2023-02-06_13_20_29-2401917268684480414
2023/02/06 21:20:30 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-06_13_20_29-2401917268684480414?project=apache-beam-testing
2023/02/06 21:20:30 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-06_13_20_29-2401917268684480414
2023/02/06 21:20:30 Job state: JOB_STATE_PENDING ...
2023/02/06 21:21:00 Job still running ...
2023/02/06 21:21:30 Job still running ...
2023/02/06 21:22:00 Job still running ...
2023/02/06 21:22:30 Job still running ...
2023/02/06 21:23:00 Job still running ...
2023/02/06 21:23:30 Job still running ...
2023/02/06 21:24:00 Job still running ...
2023/02/06 21:24:30 Job still running ...
2023/02/06 21:25:00 Job still running ...
2023/02/06 21:25:30 Job still running ...
2023/02/06 21:26:00 Job still running ...
2023/02/06 21:26:30 Job still running ...
2023/02/06 21:27:00 Job still running ...
2023/02/06 21:27:30 Job still running ...
2023/02/06 21:28:00 Job still running ...
2023/02/06 21:28:31 Job still running ...
2023/02/06 21:29:01 Job still running ...
2023/02/06 21:29:31 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-06_13_20_29-2401917268684480414 failed
--- FAIL: TestXLang_Partition (580.62s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3298.469s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675715707529173828
--- FAIL: TestBigQueryIO_BasicWriteRead (7.83s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43743 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BsGWKPTiaP" is_bounded:BOUNDED windowing_strategy_id:"w0@BsGWKPTiaP"}} windowing_strategies:{key:"w0@BsGWKPTiaP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BsGWKPTiaP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BsGWKPTiaP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BsGWKPTiaP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675715707529173828\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BsGWKPTiaP"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43743 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BsGWKPTiaP" is_bounded:BOUNDED windowing_strategy_id:"w0@BsGWKPTiaP"}} windowing_strategies:{key:"w0@BsGWKPTiaP" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BsGWKPTiaP" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BsGWKPTiaP" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BsGWKPTiaP" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675715707529173828\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BsGWKPTiaP"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2876)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1933)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 23 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00057ae80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00057ae80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048e900?, 0xc0005ce000?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc000122c50, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048e8a0?, 0xc0005ce000?}, {0xc000524420, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122c50, 0xf}, {0xc000524420, 0x52}, {0xe96fa0, 0xc000496278})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103860, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	10.874s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.063s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.051s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.084s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2f262c348ff0eff05eb877714b4a96d941139937665a2d133181955802164588
  Associated tags:
 - 20230206-203413
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-203413
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-203413].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2f262c348ff0eff05eb877714b4a96d941139937665a2d133181955802164588].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89e24f64141790291105d66c3b5db73edf99fe45b8ed47efb2029ca4269be5b1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89e24f64141790291105d66c3b5db73edf99fe45b8ed47efb2029ca4269be5b1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89e24f64141790291105d66c3b5db73edf99fe45b8ed47efb2029ca4269be5b1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:89e24f64141790291105d66c3b5db73edf99fe45b8ed47efb2029ca4269be5b1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:979d33681d6dc49dfa1195d8d564617e3dc8599b18217f3415a5def6ae5a7dd5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:979d33681d6dc49dfa1195d8d564617e3dc8599b18217f3415a5def6ae5a7dd5])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:979d33681d6dc49dfa1195d8d564617e3dc8599b18217f3415a5def6ae5a7dd5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:979d33681d6dc49dfa1195d8d564617e3dc8599b18217f3415a5def6ae5a7dd5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 45s
216 actionable tasks: 170 executed, 34 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1258

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1258/display/redirect>

Changes:


------------------------------------------
[...truncated 1012.56 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19628/go-8-1675696880475427345/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-143325"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206142047"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-143325"
      }
    ]
  },
  "name": "go-testxlang_partition-483",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/06 15:21:28 Submitted job: 2023-02-06_07_21_28-16192717198358852903
2023/02/06 15:21:28 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-06_07_21_28-16192717198358852903?project=apache-beam-testing
2023/02/06 15:21:28 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-06_07_21_28-16192717198358852903
2023/02/06 15:21:28 Job state: JOB_STATE_PENDING ...
2023/02/06 15:21:58 Job still running ...
2023/02/06 15:22:28 Job still running ...
2023/02/06 15:22:58 Job still running ...
2023/02/06 15:23:28 Job still running ...
2023/02/06 15:23:58 Job still running ...
2023/02/06 15:24:28 Job still running ...
2023/02/06 15:24:58 Job still running ...
2023/02/06 15:25:29 Job still running ...
2023/02/06 15:25:59 Job still running ...
2023/02/06 15:26:29 Job still running ...
2023/02/06 15:26:59 Job still running ...
2023/02/06 15:27:29 Job still running ...
2023/02/06 15:27:59 Job still running ...
2023/02/06 15:28:29 Job still running ...
2023/02/06 15:28:59 Job still running ...
2023/02/06 15:29:29 Job still running ...
2023/02/06 15:29:59 Job still running ...
2023/02/06 15:30:29 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-06_07_21_28-16192717198358852903 failed
--- FAIL: TestXLang_Partition (579.28s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3415.744s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675694047038449610
--- FAIL: TestBigQueryIO_BasicWriteRead (4.51s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40905 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xFFtzPcTEM" is_bounded:BOUNDED windowing_strategy_id:"w0@xFFtzPcTEM"}} windowing_strategies:{key:"w0@xFFtzPcTEM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xFFtzPcTEM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xFFtzPcTEM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xFFtzPcTEM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675694047038449610\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xFFtzPcTEM"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40905 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xFFtzPcTEM" is_bounded:BOUNDED windowing_strategy_id:"w0@xFFtzPcTEM"}} windowing_strategies:{key:"w0@xFFtzPcTEM" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xFFtzPcTEM" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xFFtzPcTEM" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xFFtzPcTEM" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675694047038449610\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xFFtzPcTEM"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00014f7c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00014f7c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fe0?, 0xc0006a0050?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc000122be0, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f80?, 0xc0006a0050?}, {0xc000550360, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122be0, 0xf}, {0xc000550360, 0x52}, {0xe96fa0, 0xc0003f8158})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102d00, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.548s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1f05909e60adcff60ba795ec80f00976fe1da8e2502610838d0d6d7752e12b88
  Associated tags:
 - 20230206-143325
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-143325
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-143325].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1f05909e60adcff60ba795ec80f00976fe1da8e2502610838d0d6d7752e12b88].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:066da4905c9d4ff177b084b9f8408db249fda220a0f3c58ef67e6f5dd2cc7ca8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:066da4905c9d4ff177b084b9f8408db249fda220a0f3c58ef67e6f5dd2cc7ca8])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:066da4905c9d4ff177b084b9f8408db249fda220a0f3c58ef67e6f5dd2cc7ca8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:066da4905c9d4ff177b084b9f8408db249fda220a0f3c58ef67e6f5dd2cc7ca8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98967982042a082dba88ee1374b2f9f7ddfbc99a80858a9efdc99827fe4ab827]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98967982042a082dba88ee1374b2f9f7ddfbc99a80858a9efdc99827fe4ab827])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98967982042a082dba88ee1374b2f9f7ddfbc99a80858a9efdc99827fe4ab827
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:98967982042a082dba88ee1374b2f9f7ddfbc99a80858a9efdc99827fe4ab827].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 39s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2gnhk3p2vgguu

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1257

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1257/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21022/go-8-1675675077653827573/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206082050"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213"
      }
    ]
  },
  "name": "go-testxlang_partition-497",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/06 09:18:06 Submitted job: 2023-02-06_01_18_05-14705673327775741861
2023/02/06 09:18:06 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-06_01_18_05-14705673327775741861?project=apache-beam-testing
2023/02/06 09:18:06 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-06_01_18_05-14705673327775741861
2023/02/06 09:18:06 Job state: JOB_STATE_PENDING ...
2023/02/06 09:18:36 Job still running ...
2023/02/06 09:19:06 Job still running ...
2023/02/06 09:19:36 Job still running ...
2023/02/06 09:20:06 Job still running ...
2023/02/06 09:20:36 Job still running ...
2023/02/06 09:21:06 Job still running ...
2023/02/06 09:21:36 Job still running ...
2023/02/06 09:22:06 Job still running ...
2023/02/06 09:22:36 Job still running ...
2023/02/06 09:23:06 Job still running ...
2023/02/06 09:23:36 Job still running ...
2023/02/06 09:24:06 Job still running ...
2023/02/06 09:24:36 Job still running ...
2023/02/06 09:25:06 Job still running ...
2023/02/06 09:25:36 Job still running ...
2023/02/06 09:26:06 Job still running ...
2023/02/06 09:26:36 Job still running ...
2023/02/06 09:27:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-06_01_18_05-14705673327775741861 failed
--- FAIL: TestXLang_Partition (579.60s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3290.865s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675672369471848895
--- FAIL: TestBigQueryIO_BasicWriteRead (4.33s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40501 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@XdpcBBXzzo" is_bounded:BOUNDED windowing_strategy_id:"w0@XdpcBBXzzo"}} windowing_strategies:{key:"w0@XdpcBBXzzo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@XdpcBBXzzo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@XdpcBBXzzo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@XdpcBBXzzo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675672369471848895\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"XdpcBBXzzo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40501 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@XdpcBBXzzo" is_bounded:BOUNDED windowing_strategy_id:"w0@XdpcBBXzzo"}} windowing_strategies:{key:"w0@XdpcBBXzzo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@XdpcBBXzzo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@XdpcBBXzzo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@XdpcBBXzzo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675672369471848895\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"XdpcBBXzzo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00048ef40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00048ef40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fc0?, 0xc0000bb6d0?}, {0x110f943, 0x39}, {0xc0001e0000?, 0xa969c0?, 0x1?}, {0xc000042de0, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f60?, 0xc0000bb6d0?}, {0xc00059c3c0, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f7d385df998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042de0, 0xf}, {0xc00059c3c0, 0x52}, {0xe96fa0, 0xc0001303b0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000494d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000494d00, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.367s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.036s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:69a64f42754eb91c115ea7d5adc5a06c7faa501972739beafec97eae8b3d75b6
Deleted: sha256:18369f71addc6bab2f9792a71dddcb555891b45f041a51eb378fedbbf1c36c46
Deleted: sha256:5d49cc48e5a6ee77a145024b57b89b763c5c641ab561070e3eb39761b19d3b29
Deleted: sha256:e129461e00f7d412bcf326dae1b27179e3de70412d493302359890178abac9af
Deleted: sha256:4564d1e2f9a0d92b64a54698e0f4318d5f3257a996dfa0b3ec7385a8697f5100
Deleted: sha256:24ff53de25025c10cb33b6066a79c32932ebf7cf5fa3a58e0dd220edc161882a
Deleted: sha256:b4b71bf8fda7b9c4755fa3e8f59afddd2fb1ae0d0a42a29dce23790520634f7f
Deleted: sha256:8a7379dc3e4db32f51947e0a7efb2ab40987a3d89d5ca400bc85e32dc60000ff
Deleted: sha256:c026f9e8641c2f99b1ab0a087e94af0349e2268307b0f07d2403957f4f107a72
Deleted: sha256:a9e63d8a016ff431e1a2c5626e002bcf7b4eedb226b0245d14ca94c6cfc7d7c4
Deleted: sha256:f37f73f0b843586a9778d0deae031505d7bf7f6536b24ba20fc7f9e4134682b9
Deleted: sha256:d4a8299515bf899f05664f1decdc63aa8e94524cb7494054f4209f40647db0f7
Deleted: sha256:a357b1bd5c49d479892dcbc3ce00c1d9cd5e13d3efb2ace0b51a27d3b798ff8a
Deleted: sha256:7da693cd86b6020a39dc4af3570cf9905ce902e925528e2df8f589ec0937c2e6
Deleted: sha256:e0e084f5c277a512b4c67987c0dda4a116816518a96a2f63a1c2b45ba92dc631
Deleted: sha256:3d5888f99ef2c03e055f724af74bfd25ef75c907f78d174352fcdddb84ccc73d
Deleted: sha256:adf1e8e817fa531266d48e37ea0107a70d55d941e21abf0a2ac6c82b338ddf3c
Deleted: sha256:32368f48e3696fc7836358186d3df988d604da54f5c21c6ac04c9ab24832b183
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:69a64f42754eb91c115ea7d5adc5a06c7faa501972739beafec97eae8b3d75b6
  Associated tags:
 - 20230206-083213
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-083213].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:69a64f42754eb91c115ea7d5adc5a06c7faa501972739beafec97eae8b3d75b6].
$ rm -rf /tmp/tmp.cF4kwH11Ra
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9d6f8383f2cea800d78873e9344f984ad671519bea7464dd2075e39d63633615].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206082050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206082050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206082050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7ab093f200e98f92f0375b72794117ff5ead1208622b3b3ad89e5d67613622cf].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1843533.
Stopping expansion service pid: 1843534.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 11s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1256

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1256/display/redirect?page=changes>

Changes:

[noreply] Clarify llm download/loading instructions (#25145)


------------------------------------------
[...truncated 1013.06 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test19994/go-8-1675653473315217213/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-023210"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206022047"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-023210"
      }
    ]
  },
  "name": "go-testxlang_partition-507",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/06 03:18:01 Submitted job: 2023-02-05_19_18_01-15548315160743877469
2023/02/06 03:18:01 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-05_19_18_01-15548315160743877469?project=apache-beam-testing
2023/02/06 03:18:01 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-05_19_18_01-15548315160743877469
2023/02/06 03:18:01 Job state: JOB_STATE_PENDING ...
2023/02/06 03:18:31 Job still running ...
2023/02/06 03:19:01 Job still running ...
2023/02/06 03:19:31 Job still running ...
2023/02/06 03:20:01 Job still running ...
2023/02/06 03:20:32 Job still running ...
2023/02/06 03:21:02 Job still running ...
2023/02/06 03:21:32 Job still running ...
2023/02/06 03:22:02 Job still running ...
2023/02/06 03:22:32 Job still running ...
2023/02/06 03:23:02 Job still running ...
2023/02/06 03:23:32 Job still running ...
2023/02/06 03:24:02 Job still running ...
2023/02/06 03:24:32 Job still running ...
2023/02/06 03:25:02 Job still running ...
2023/02/06 03:25:32 Job still running ...
2023/02/06 03:26:02 Job still running ...
2023/02/06 03:26:32 Job still running ...
2023/02/06 03:27:02 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-05_19_18_01-15548315160743877469 failed
--- FAIL: TestXLang_Partition (579.74s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3290.627s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675650765517119061
--- FAIL: TestBigQueryIO_BasicWriteRead (4.26s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41769 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MEoUjTgPOo" is_bounded:BOUNDED windowing_strategy_id:"w0@MEoUjTgPOo"}} windowing_strategies:{key:"w0@MEoUjTgPOo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MEoUjTgPOo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MEoUjTgPOo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MEoUjTgPOo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675650765517119061\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MEoUjTgPOo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41769 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@MEoUjTgPOo" is_bounded:BOUNDED windowing_strategy_id:"w0@MEoUjTgPOo"}} windowing_strategies:{key:"w0@MEoUjTgPOo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@MEoUjTgPOo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@MEoUjTgPOo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@MEoUjTgPOo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675650765517119061\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"MEoUjTgPOo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 12 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0005b03c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0005b03c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480840?, 0xc000652000?}, {0x110f943, 0x39}, {0xc0000ee180?, 0xa969c0?, 0x1?}, {0xc000119b60, 0xf}, 0xc0001a9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004807e0?, 0xc000652000?}, {0xc00004cd80, 0x52}, {0x1?}, {0xc0001a9ea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000119b60, 0xf}, {0xc00004cd80, 0x52}, {0xe96fa0, 0xc0003f8108})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000642ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000642ea0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.298s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4cbcfb5433160eab9932c666a24de3c94ed3b953af35b9fb2b5a111bb405301a
  Associated tags:
 - 20230206-023210
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-023210
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230206-023210].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4cbcfb5433160eab9932c666a24de3c94ed3b953af35b9fb2b5a111bb405301a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f8564d61f38a4456be47433783adb13e78e84ffca3a88a1ec2385687d4090832]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230206022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f8564d61f38a4456be47433783adb13e78e84ffca3a88a1ec2385687d4090832])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f8564d61f38a4456be47433783adb13e78e84ffca3a88a1ec2385687d4090832
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f8564d61f38a4456be47433783adb13e78e84ffca3a88a1ec2385687d4090832].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206022047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ac9b14e56e7cb4d77cde7c04841485c43d56195dfa4438ab0565ab2c5349632a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230206022047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ac9b14e56e7cb4d77cde7c04841485c43d56195dfa4438ab0565ab2c5349632a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ac9b14e56e7cb4d77cde7c04841485c43d56195dfa4438ab0565ab2c5349632a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:ac9b14e56e7cb4d77cde7c04841485c43d56195dfa4438ab0565ab2c5349632a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 10s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1255

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1255/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4101/go-8-1675631897847453109/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205202048"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233"
      }
    ]
  },
  "name": "go-testxlang_partition-851",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/05 21:18:25 Submitted job: 2023-02-05_13_18_25-11491175357124017528
2023/02/05 21:18:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-05_13_18_25-11491175357124017528?project=apache-beam-testing
2023/02/05 21:18:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-05_13_18_25-11491175357124017528
2023/02/05 21:18:26 Job state: JOB_STATE_PENDING ...
2023/02/05 21:18:56 Job still running ...
2023/02/05 21:19:26 Job still running ...
2023/02/05 21:19:56 Job still running ...
2023/02/05 21:20:26 Job still running ...
2023/02/05 21:20:56 Job still running ...
2023/02/05 21:21:26 Job still running ...
2023/02/05 21:21:56 Job still running ...
2023/02/05 21:22:26 Job still running ...
2023/02/05 21:22:56 Job still running ...
2023/02/05 21:23:26 Job still running ...
2023/02/05 21:23:56 Job still running ...
2023/02/05 21:24:26 Job still running ...
2023/02/05 21:24:56 Job still running ...
2023/02/05 21:25:26 Job still running ...
2023/02/05 21:25:56 Job still running ...
2023/02/05 21:26:26 Job still running ...
2023/02/05 21:26:56 Job still running ...
2023/02/05 21:27:26 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-05_13_18_25-11491175357124017528 failed
--- FAIL: TestXLang_Partition (579.38s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3289.028s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675629191265893500
--- FAIL: TestBigQueryIO_BasicWriteRead (4.29s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42223 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@swmnRZwiga" is_bounded:BOUNDED windowing_strategy_id:"w0@swmnRZwiga"}} windowing_strategies:{key:"w0@swmnRZwiga" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@swmnRZwiga" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@swmnRZwiga" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@swmnRZwiga" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675629191265893500\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"swmnRZwiga"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42223 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@swmnRZwiga" is_bounded:BOUNDED windowing_strategy_id:"w0@swmnRZwiga"}} windowing_strategies:{key:"w0@swmnRZwiga" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@swmnRZwiga" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@swmnRZwiga" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@swmnRZwiga" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675629191265893500\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"swmnRZwiga"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000564a00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000564a00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001682e0?, 0xc000138230?}, {0x110f943, 0x39}, {0xc0004b20c0?, 0xa969c0?, 0x1?}, {0xc00048ecf0, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168260?, 0xc000138230?}, {0xc00010e960, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7fc1b43dd288?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ecf0, 0xf}, {0xc00010e960, 0x52}, {0xe96fa0, 0xc0005c6070})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000497040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000497040, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.327s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4488c55320dfa4a3da53ccd31df54c0db4a6166913fd209e34b77bcdc974e5c9
Deleted: sha256:793b9443949732defba91ca37944c177151942b3f60f97d3fdcd4f54dbc06cb8
Deleted: sha256:a646521a4e48b97123134847fbd088bc1ba2680b5a1b0553c4d3f42a7dc1d8bc
Deleted: sha256:c76bcb13175f396abce7a53df9dc9810bfb7846210c53f5ca0c10e2e9013278f
Deleted: sha256:17ef8f408becf805d65d77235724ff86b28cbd6317e2142cabbc257984f38ae0
Deleted: sha256:2e6c2216b551b06b721f39fbc9aa694014acfbcc5dc060b94ab2115e39531824
Deleted: sha256:ba5491dda0850acf7b244f20f0c75e426868041e701909391f03380a0531ead4
Deleted: sha256:00fac152c9b813bca3a31fb15aafd5ca4c6e303401af747fda126fde8ef873cc
Deleted: sha256:7657466742f1cbf0b98478ec7f6c42c4758300fdefaab6738532efb0aa849d7a
Deleted: sha256:9e0d27df0adf0fde943d68d41b8ab9945161ed3abe85906071cf72b0e23d75d0
Deleted: sha256:dfca6341a2d4d68a471ff39c88df20f4f6990b4523cf3aca1474de721ca5dbb8
Deleted: sha256:483a6d666e0cc0f114baa9452bacc8bf957843f114f6d088187c2868dbfe91a6
Deleted: sha256:c02c43848d6675002bb5044d9bb788df295b3c615917cfd44e645569d0920b50
Deleted: sha256:316f4200a3600785e53812a97012b02b2b940dbd043c55ec5cd15df0631f54b5
Deleted: sha256:97841e44eea5a46a916380d3a04f088fe7393704478660cb805397faa60ce2c7
Deleted: sha256:a028ff77a41300a04cf987712ce09cf9ea2c8bbcd89cf7f22e086ee1a89d5292
Deleted: sha256:722df13cec2376a213765eb1f874ebd6c94e890cbe30699fa676536d9cfe4427
Deleted: sha256:d8a57aefab5b695c426a334a9b7e48f96a74cbbe9d6670b17a86aa5086b140a8
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4488c55320dfa4a3da53ccd31df54c0db4a6166913fd209e34b77bcdc974e5c9
  Associated tags:
 - 20230205-203233
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-203233].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4488c55320dfa4a3da53ccd31df54c0db4a6166913fd209e34b77bcdc974e5c9].
$ rm -rf /tmp/tmp.U0M70RIxLB
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205202048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:afbf13869fc47ec48634cb8f409c40d06e729188df5fa15d1f3c4dec8721c2a2].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205202048
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205202048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205202048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:b10f340663313a4f8558cd99d7b931f5a8f682c2f11ad3577edc297b42cb0cc4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1627280.
Stopping expansion service pid: 1627281.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 33s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1254

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1254/display/redirect>

Changes:


------------------------------------------
[...truncated 1016.28 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28018/go-8-1675610339825291940/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-143214"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205142045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-143214"
      }
    ]
  },
  "name": "go-testxlang_partition-21",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/05 15:19:08 Submitted job: 2023-02-05_07_19_07-9087016942603608292
2023/02/05 15:19:08 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-05_07_19_07-9087016942603608292?project=apache-beam-testing
2023/02/05 15:19:08 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-05_07_19_07-9087016942603608292
2023/02/05 15:19:08 Job state: JOB_STATE_PENDING ...
2023/02/05 15:19:38 Job still running ...
2023/02/05 15:20:08 Job still running ...
2023/02/05 15:20:38 Job still running ...
2023/02/05 15:21:08 Job still running ...
2023/02/05 15:21:38 Job still running ...
2023/02/05 15:22:08 Job still running ...
2023/02/05 15:22:38 Job still running ...
2023/02/05 15:23:08 Job still running ...
2023/02/05 15:23:38 Job still running ...
2023/02/05 15:24:08 Job still running ...
2023/02/05 15:24:40 Job still running ...
2023/02/05 15:25:10 Job still running ...
2023/02/05 15:25:40 Job still running ...
2023/02/05 15:26:10 Job still running ...
2023/02/05 15:26:40 Job still running ...
2023/02/05 15:27:10 Job still running ...
2023/02/05 15:27:40 Job still running ...
2023/02/05 15:28:11 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-05_07_19_07-9087016942603608292 failed
--- FAIL: TestXLang_Partition (581.47s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3354.777s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675607569639861495
--- FAIL: TestBigQueryIO_BasicWriteRead (4.25s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44637 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KkuEkmROxV" is_bounded:BOUNDED windowing_strategy_id:"w0@KkuEkmROxV"}} windowing_strategies:{key:"w0@KkuEkmROxV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KkuEkmROxV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KkuEkmROxV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KkuEkmROxV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675607569639861495\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KkuEkmROxV"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44637 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KkuEkmROxV" is_bounded:BOUNDED windowing_strategy_id:"w0@KkuEkmROxV"}} windowing_strategies:{key:"w0@KkuEkmROxV" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KkuEkmROxV" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KkuEkmROxV" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KkuEkmROxV" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675607569639861495\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KkuEkmROxV"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0005df340})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0005df340})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000168fc0?, 0xc0001162d0?}, {0x110f943, 0x39}, {0xc00015e180?, 0xa969c0?, 0x1?}, {0xc000137d40, 0xf}, 0xc00001bd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000168f60?, 0xc0001162d0?}, {0xc0005a4360, 0x52}, {0x1?}, {0xc00001bea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137d40, 0xf}, {0xc0005a4360, 0x52}, {0xe96fa0, 0xc0003f0218})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000493040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000493040, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.290s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ef6ccce380d23d141baa5564f3d430501dd64318652705e19b854c553ef258be
  Associated tags:
 - 20230205-143214
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-143214
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-143214].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ef6ccce380d23d141baa5564f3d430501dd64318652705e19b854c553ef258be].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8eae5ebdf4cb54374835b9b4716956b2c29a154ecc7c24ed0e3b59be393374cd]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8eae5ebdf4cb54374835b9b4716956b2c29a154ecc7c24ed0e3b59be393374cd])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8eae5ebdf4cb54374835b9b4716956b2c29a154ecc7c24ed0e3b59be393374cd
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8eae5ebdf4cb54374835b9b4716956b2c29a154ecc7c24ed0e3b59be393374cd].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:02ca7110f08d381458b08060da6923d7290abbb481fa87ef72a18abe5a9136cc]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:02ca7110f08d381458b08060da6923d7290abbb481fa87ef72a18abe5a9136cc])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:02ca7110f08d381458b08060da6923d7290abbb481fa87ef72a18abe5a9136cc
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:02ca7110f08d381458b08060da6923d7290abbb481fa87ef72a18abe5a9136cc].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 20s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1253

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1253/display/redirect>

Changes:


------------------------------------------
[...truncated 1022.08 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test14389/go-8-1675588768351574946/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-083316"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205082045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-083316"
      }
    ]
  },
  "name": "go-testxlang_partition-856",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/05 09:19:36 Submitted job: 2023-02-05_01_19_36-5032788741742903421
2023/02/05 09:19:36 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-05_01_19_36-5032788741742903421?project=apache-beam-testing
2023/02/05 09:19:36 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-05_01_19_36-5032788741742903421
2023/02/05 09:19:36 Job state: JOB_STATE_PENDING ...
2023/02/05 09:20:06 Job still running ...
2023/02/05 09:20:36 Job still running ...
2023/02/05 09:21:06 Job still running ...
2023/02/05 09:21:36 Job still running ...
2023/02/05 09:22:06 Job still running ...
2023/02/05 09:22:36 Job still running ...
2023/02/05 09:23:06 Job still running ...
2023/02/05 09:23:36 Job still running ...
2023/02/05 09:24:07 Job still running ...
2023/02/05 09:24:37 Job still running ...
2023/02/05 09:25:07 Job still running ...
2023/02/05 09:25:37 Job still running ...
2023/02/05 09:26:07 Job still running ...
2023/02/05 09:26:37 Job still running ...
2023/02/05 09:27:07 Job still running ...
2023/02/05 09:27:37 Job still running ...
2023/02/05 09:28:07 Job still running ...
2023/02/05 09:28:37 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-05_01_19_36-5032788741742903421 failed
--- FAIL: TestXLang_Partition (579.51s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3319.842s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675586031073014023
--- FAIL: TestBigQueryIO_BasicWriteRead (4.23s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40993 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@sDcYBXqYTe" is_bounded:BOUNDED windowing_strategy_id:"w0@sDcYBXqYTe"}} windowing_strategies:{key:"w0@sDcYBXqYTe" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@sDcYBXqYTe" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@sDcYBXqYTe" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@sDcYBXqYTe" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675586031073014023\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"sDcYBXqYTe"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40993 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@sDcYBXqYTe" is_bounded:BOUNDED windowing_strategy_id:"w0@sDcYBXqYTe"}} windowing_strategies:{key:"w0@sDcYBXqYTe" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@sDcYBXqYTe" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@sDcYBXqYTe" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@sDcYBXqYTe" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675586031073014023\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"sDcYBXqYTe"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00055c400})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00055c400})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00011f240?, 0xc0001299f0?}, {0x110f943, 0x39}, {0xc0000ee0c0?, 0xa969c0?, 0x1?}, {0xc000043df0, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00011f1e0?, 0xc0001299f0?}, {0xc00004ca20, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0x7fb18c4d4068?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043df0, 0xf}, {0xc00004ca20, 0x52}, {0xe96fa0, 0xc00013d110})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103ba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103ba0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.263s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:506ff2e9e54a7866e7519a2932e8381a23ba41f68b3ed1553d273a2aba7487db
  Associated tags:
 - 20230205-083316
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-083316
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-083316].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:506ff2e9e54a7866e7519a2932e8381a23ba41f68b3ed1553d273a2aba7487db].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:99969e0c3db30f1cf240139f7f75ad8d3e496329f4093e638b7be21e0ec9743c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:99969e0c3db30f1cf240139f7f75ad8d3e496329f4093e638b7be21e0ec9743c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:99969e0c3db30f1cf240139f7f75ad8d3e496329f4093e638b7be21e0ec9743c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:99969e0c3db30f1cf240139f7f75ad8d3e496329f4093e638b7be21e0ec9743c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d88e95103186cd31424718d75bbdcf2664eb7d2b7f58d28712cd8e789bb8bfe1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d88e95103186cd31424718d75bbdcf2664eb7d2b7f58d28712cd8e789bb8bfe1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d88e95103186cd31424718d75bbdcf2664eb7d2b7f58d28712cd8e789bb8bfe1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d88e95103186cd31424718d75bbdcf2664eb7d2b7f58d28712cd8e789bb8bfe1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 48s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1252

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1252/display/redirect>

Changes:


------------------------------------------
[...truncated 1001.43 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8469/go-8-1675567076540090930/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-023213"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205022049"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-023213"
      }
    ]
  },
  "name": "go-testxlang_partition-8",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/05 03:18:04 Submitted job: 2023-02-04_19_18_04-13724980645653348042
2023/02/05 03:18:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-04_19_18_04-13724980645653348042?project=apache-beam-testing
2023/02/05 03:18:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-04_19_18_04-13724980645653348042
2023/02/05 03:18:04 Job state: JOB_STATE_PENDING ...
2023/02/05 03:18:34 Job still running ...
2023/02/05 03:19:05 Job still running ...
2023/02/05 03:19:35 Job still running ...
2023/02/05 03:20:05 Job still running ...
2023/02/05 03:20:35 Job still running ...
2023/02/05 03:21:05 Job still running ...
2023/02/05 03:21:35 Job still running ...
2023/02/05 03:22:05 Job still running ...
2023/02/05 03:22:35 Job still running ...
2023/02/05 03:23:05 Job still running ...
2023/02/05 03:23:35 Job still running ...
2023/02/05 03:24:05 Job still running ...
2023/02/05 03:24:35 Job still running ...
2023/02/05 03:25:05 Job still running ...
2023/02/05 03:25:35 Job still running ...
2023/02/05 03:26:05 Job still running ...
2023/02/05 03:26:35 Job still running ...
2023/02/05 03:27:05 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-04_19_18_04-13724980645653348042 failed
--- FAIL: TestXLang_Partition (579.59s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3291.440s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675564367742732729
--- FAIL: TestBigQueryIO_BasicWriteRead (4.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38773 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xWpOBUHcLN" is_bounded:BOUNDED windowing_strategy_id:"w0@xWpOBUHcLN"}} windowing_strategies:{key:"w0@xWpOBUHcLN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xWpOBUHcLN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xWpOBUHcLN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xWpOBUHcLN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675564367742732729\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xWpOBUHcLN"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38773 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xWpOBUHcLN" is_bounded:BOUNDED windowing_strategy_id:"w0@xWpOBUHcLN"}} windowing_strategies:{key:"w0@xWpOBUHcLN" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xWpOBUHcLN" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xWpOBUHcLN" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xWpOBUHcLN" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675564367742732729\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xWpOBUHcLN"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000194f40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000194f40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048e6e0?, 0xc000130050?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc00012b740, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048e680?, 0xc000130050?}, {0xc00004ca80, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00012b740, 0xf}, {0xc00004ca80, 0x52}, {0xe96fa0, 0xc0003f6168})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582d00, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.246s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:38edbdcfde4e9cc70699ca65efa9d0f029c41a49bd110e73bc9cade21a0c8295
  Associated tags:
 - 20230205-023213
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-023213
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230205-023213].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:38edbdcfde4e9cc70699ca65efa9d0f029c41a49bd110e73bc9cade21a0c8295].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:13475f24fbc6844e7517a9c0fa53269eef7978d5c4080e99651266af03d3e51e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230205022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:13475f24fbc6844e7517a9c0fa53269eef7978d5c4080e99651266af03d3e51e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:13475f24fbc6844e7517a9c0fa53269eef7978d5c4080e99651266af03d3e51e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:13475f24fbc6844e7517a9c0fa53269eef7978d5c4080e99651266af03d3e51e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9f979dd4729a120337f29d3420fec084b587e02da35b7ff90f7a5c9c5e5f964a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230205022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9f979dd4729a120337f29d3420fec084b587e02da35b7ff90f7a5c9c5e5f964a])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9f979dd4729a120337f29d3420fec084b587e02da35b7ff90f7a5c9c5e5f964a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9f979dd4729a120337f29d3420fec084b587e02da35b7ff90f7a5c9c5e5f964a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 12s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1251

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1251/display/redirect?page=changes>

Changes:

[noreply] Basic SchemaTransform implementation for SQLTransform. (#25177)

[noreply] issue24170 google colab link added (#24820)


------------------------------------------
[...truncated 514.88 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17682/go-8-1675545508787487458/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204202052"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-203244"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-203244"
      }
    ]
  },
  "name": "go-testxlang_partition-265",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/04 21:18:37 Submitted job: 2023-02-04_13_18_36-3242576955265679157
2023/02/04 21:18:37 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-04_13_18_36-3242576955265679157?project=apache-beam-testing
2023/02/04 21:18:37 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-04_13_18_36-3242576955265679157
2023/02/04 21:18:37 Job state: JOB_STATE_PENDING ...
2023/02/04 21:19:07 Job still running ...
2023/02/04 21:19:37 Job still running ...
2023/02/04 21:20:07 Job still running ...
2023/02/04 21:20:37 Job still running ...
2023/02/04 21:21:07 Job still running ...
2023/02/04 21:21:37 Job still running ...
2023/02/04 21:22:07 Job still running ...
2023/02/04 21:22:37 Job still running ...
2023/02/04 21:23:07 Job still running ...
2023/02/04 21:23:37 Job still running ...
2023/02/04 21:24:07 Job still running ...
2023/02/04 21:24:37 Job still running ...
2023/02/04 21:25:07 Job still running ...
2023/02/04 21:25:37 Job still running ...
2023/02/04 21:26:07 Job still running ...
2023/02/04 21:26:37 Job still running ...
2023/02/04 21:27:07 Job still running ...
2023/02/04 21:27:38 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-04_13_18_36-3242576955265679157 failed
--- FAIL: TestXLang_Partition (579.47s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3290.265s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675542801074671772
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41211 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xIXXGjVvHo" is_bounded:BOUNDED windowing_strategy_id:"w0@xIXXGjVvHo"}} windowing_strategies:{key:"w0@xIXXGjVvHo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xIXXGjVvHo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xIXXGjVvHo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xIXXGjVvHo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675542801074671772\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xIXXGjVvHo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41211 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@xIXXGjVvHo" is_bounded:BOUNDED windowing_strategy_id:"w0@xIXXGjVvHo"}} windowing_strategies:{key:"w0@xIXXGjVvHo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@xIXXGjVvHo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@xIXXGjVvHo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@xIXXGjVvHo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675542801074671772\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"xIXXGjVvHo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00062d380})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00062d380})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00065cec0?, 0xc000495680?}, {0x110f943, 0x39}, {0xc0000f00c0?, 0xa969c0?, 0x1?}, {0xc00061b420, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00065ce60?, 0xc000495680?}, {0xc000666360, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f26e9665448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00061b420, 0xf}, {0xc000666360, 0x52}, {0xe96fa0, 0xc000043190})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000102ea0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000102ea0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.351s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92fb265d5636d4db08f68ac647f67f171d7ad71cbd413ad6d84641de562a3b25
  Associated tags:
 - 20230204-203244
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-203244
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-203244].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:92fb265d5636d4db08f68ac647f67f171d7ad71cbd413ad6d84641de562a3b25].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204202052]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f18767669440e71a53123c3c28434b5335fe06ca9af30c84e54553dc6637260d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204202052] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f18767669440e71a53123c3c28434b5335fe06ca9af30c84e54553dc6637260d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f18767669440e71a53123c3c28434b5335fe06ca9af30c84e54553dc6637260d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:f18767669440e71a53123c3c28434b5335fe06ca9af30c84e54553dc6637260d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204202052]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a15a2e279354499492aa7dde1112e8169687f61f4cc69f0db0ec8e08fba52db9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204202052] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a15a2e279354499492aa7dde1112e8169687f61f4cc69f0db0ec8e08fba52db9])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a15a2e279354499492aa7dde1112e8169687f61f4cc69f0db0ec8e08fba52db9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:a15a2e279354499492aa7dde1112e8169687f61f4cc69f0db0ec8e08fba52db9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 42s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1250

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1250/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test31064/go-8-1675523936519096369/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204142047"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212"
      }
    ]
  },
  "name": "go-testxlang_partition-831",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/04 15:19:04 Submitted job: 2023-02-04_07_19_04-6606111428184299058
2023/02/04 15:19:04 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-04_07_19_04-6606111428184299058?project=apache-beam-testing
2023/02/04 15:19:04 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-04_07_19_04-6606111428184299058
2023/02/04 15:19:04 Job state: JOB_STATE_PENDING ...
2023/02/04 15:19:34 Job still running ...
2023/02/04 15:20:04 Job still running ...
2023/02/04 15:20:35 Job still running ...
2023/02/04 15:21:05 Job still running ...
2023/02/04 15:21:35 Job still running ...
2023/02/04 15:22:05 Job still running ...
2023/02/04 15:22:35 Job still running ...
2023/02/04 15:23:05 Job still running ...
2023/02/04 15:23:35 Job still running ...
2023/02/04 15:24:05 Job still running ...
2023/02/04 15:24:35 Job still running ...
2023/02/04 15:25:05 Job still running ...
2023/02/04 15:25:35 Job still running ...
2023/02/04 15:26:05 Job still running ...
2023/02/04 15:26:35 Job still running ...
2023/02/04 15:27:05 Job still running ...
2023/02/04 15:27:35 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-04_07_19_04-6606111428184299058 failed
--- FAIL: TestXLang_Partition (549.35s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3321.494s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675521167498857188
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37879 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZuOhdKqzpo" is_bounded:BOUNDED windowing_strategy_id:"w0@ZuOhdKqzpo"}} windowing_strategies:{key:"w0@ZuOhdKqzpo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZuOhdKqzpo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZuOhdKqzpo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZuOhdKqzpo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675521167498857188\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZuOhdKqzpo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37879 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZuOhdKqzpo" is_bounded:BOUNDED windowing_strategy_id:"w0@ZuOhdKqzpo"}} windowing_strategies:{key:"w0@ZuOhdKqzpo" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZuOhdKqzpo" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZuOhdKqzpo" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZuOhdKqzpo" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675521167498857188\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZuOhdKqzpo"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0006a8540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0006a8540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00010ebe0?, 0xc0000bc960?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc0003f8dd0, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00010eb80?, 0xc0000bc960?}, {0xc00004c9c0, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0x7ff5b80b9410?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f8dd0, 0xf}, {0xc00004c9c0, 0x52}, {0xe96fa0, 0xc00059ac30})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.352s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aadfd3391f506fc18673ed8549eeb7f71ec30a67314875d0d882b0cbb40d314f
Deleted: sha256:9acea9d5b6befc337316dc5e4d09d8f438087a3998cd6daeab5e5540435bf9f1
Deleted: sha256:2479191e67839886e11ba2f816776d24624dcfe882738c4763b80fa007427db5
Deleted: sha256:f45eb3743fadfddf8e224f5b6c39361176036bbc4fd70953b1b79b40294b9955
Deleted: sha256:5da3ef8c10b3bd8ac61fd021574f3e66f027cac51440a00839ddca31dfe581d1
Deleted: sha256:32726921af81bd7e44bd8c3ae0513b6079ac9ebbb51907af5ca98bd5c3598d32
Deleted: sha256:e2159b0bb08cfdb4f2cd788743875b918a621fc5649da014af7a63d3facf5eeb
Deleted: sha256:78e1ee679e810101ab6b0341a9c804fb0a1e27022a5bbed6cb992da4a3c12607
Deleted: sha256:14c72ebe57add044ceb668249191a8cb6c014e49bbd72886c45b62e7bd5425fb
Deleted: sha256:761b05a5ded696d2ca0d098a2585ee6709437014c5add99309c05ca0c4e1c9a0
Deleted: sha256:c1b49e678cc2d8b52a38996b4b7b5fa9b4f0965181c63cb5c9a2728488fa0255
Deleted: sha256:eaac979de7639f0d6346f25654f915cc33f088e424b2478bcc2c4dc41f6b1b26
Deleted: sha256:91310e0ad3e18696de782a1d33e0d2239869e524d60e7743e52ba1c823ecd347
Deleted: sha256:5d0732f0b103523c35da65168548d8dae107bf797c477cb74f07ad83d18bb2dc
Deleted: sha256:8079cfa97c13a46bb1785aeeb857b823a3df95b364bb3899afe61447c81a861d
Deleted: sha256:b638a5b1ed43edff5be48a21bc353ddc8e0664db9f884c83acd39a1b1e52033b
Deleted: sha256:bcbb5fb5955e3a0d0be14387e6e9c41887d14de3d3b2c1e486a126cc6dabd9e9
Deleted: sha256:e1fb14bc25392efe5b226edd3c5867538d876f0831bea55d14adf23ac75effe6
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aadfd3391f506fc18673ed8549eeb7f71ec30a67314875d0d882b0cbb40d314f
  Associated tags:
 - 20230204-143212
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-143212].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:aadfd3391f506fc18673ed8549eeb7f71ec30a67314875d0d882b0cbb40d314f].
$ rm -rf /tmp/tmp.VKJCUQTWBA
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3594a6fb3e426cc1b9b3f941c2c5daf6085ba237061e6da166c0cfcaa8075433].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:89e0c1d2e1cd82efa0869a851da1eaa525bb32367953c4cc7e608dd7557be087].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 855727.
Stopping expansion service pid: 855728.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 44s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1249

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1249/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15105/go-8-1675502364385677116/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204082045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211"
      }
    ]
  },
  "name": "go-testxlang_partition-12",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/04 09:19:33 Submitted job: 2023-02-04_01_19_32-7581515536363028414
2023/02/04 09:19:33 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-04_01_19_32-7581515536363028414?project=apache-beam-testing
2023/02/04 09:19:33 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-04_01_19_32-7581515536363028414
2023/02/04 09:19:33 Job state: JOB_STATE_PENDING ...
2023/02/04 09:20:03 Job still running ...
2023/02/04 09:20:33 Job still running ...
2023/02/04 09:21:03 Job still running ...
2023/02/04 09:21:33 Job still running ...
2023/02/04 09:22:03 Job still running ...
2023/02/04 09:22:33 Job still running ...
2023/02/04 09:23:03 Job still running ...
2023/02/04 09:23:33 Job still running ...
2023/02/04 09:24:03 Job still running ...
2023/02/04 09:24:33 Job still running ...
2023/02/04 09:25:03 Job still running ...
2023/02/04 09:25:33 Job still running ...
2023/02/04 09:26:03 Job still running ...
2023/02/04 09:26:33 Job still running ...
2023/02/04 09:27:03 Job still running ...
2023/02/04 09:27:33 Job still running ...
2023/02/04 09:28:03 Job still running ...
2023/02/04 09:28:34 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-04_01_19_32-7581515536363028414 failed
--- FAIL: TestXLang_Partition (579.94s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3381.507s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675499565966585623
--- FAIL: TestBigQueryIO_BasicWriteRead (4.39s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36121 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@bywtnTjOyq" is_bounded:BOUNDED windowing_strategy_id:"w0@bywtnTjOyq"}} windowing_strategies:{key:"w0@bywtnTjOyq" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@bywtnTjOyq" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@bywtnTjOyq" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@bywtnTjOyq" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675499565966585623\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"bywtnTjOyq"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36121 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@bywtnTjOyq" is_bounded:BOUNDED windowing_strategy_id:"w0@bywtnTjOyq"}} windowing_strategies:{key:"w0@bywtnTjOyq" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@bywtnTjOyq" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@bywtnTjOyq" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@bywtnTjOyq" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675499565966585623\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"bywtnTjOyq"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000471540})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000471540})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000489060?, 0xc0004af810?}, {0x110f943, 0x39}, {0xc0000f00c0?, 0xa969c0?, 0x1?}, {0xc000126d70, 0xf}, 0xc000175d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000489000?, 0xc0004af810?}, {0xc0004ba540, 0x52}, {0x1?}, {0xc000175ea8, 0x2, 0x7f61fbf0b448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000126d70, 0xf}, {0xc0004ba540, 0x52}, {0xe96fa0, 0xc000042280})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004931e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004931e0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.426s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87b6c8e9de27bde0d30602de328726dd17aac943fe09b031a01d4215fd63e874
Deleted: sha256:26a7578b7300a8675e057ac5ddcab7960169a8d22e32db698896bedef0f6de15
Deleted: sha256:7ae7726056ebedd769249a5ee3441aff7ef84e1719dfa3acf4a760a105d7448b
Deleted: sha256:18c024a1c5dea49155ec0c537dce0c06ca33d3c87b499b9a5a452c5999bd0a47
Deleted: sha256:402bac0de0e3f23edbb51584f2f9aa9e1cf17d051ec795b3d6aea5627928f514
Deleted: sha256:64e757829c04e21b874b37866efc65cb6dc329bd37c33059822532efcdc12c4b
Deleted: sha256:65670c0f5c5d615c31cd1b3a1fd37f2ac2b7994a08e7bf7d11ae8bd6873a08c9
Deleted: sha256:f644421ddfe803e05875522b8ec8e721dffa7f4e289abf88462b3df702819534
Deleted: sha256:0c2d01ec9bd15676327e9711bfd8aed235eaffe91e457fbefa8d93836cd84c82
Deleted: sha256:3ffa3f633dae18b95ede15fe2cf9583a1c5c714128af8ed45ff645275fa1c1c7
Deleted: sha256:4fe72fe02d9f7f57c0df846aa46e4d3f485b69366f5c9889bc45206abe3f3e6c
Deleted: sha256:5e0622bf43eac64511faa79f39cbe69e15240c4c799a3c1ee2887222bff94321
Deleted: sha256:a280f7c09f410f2bad377c1e6475ace8f1c9c5298ee3dac1697593151f6b0ccb
Deleted: sha256:66eee3cf17e875f83e2044bf990433d94f4376502f1c9238ff95f2cd0fea8f10
Deleted: sha256:06176e84d6531b01899bf3fb6bbfbf46616d80b34b1c0f42a632e0c03a50a15e
Deleted: sha256:8f343d38026b7ea441ed9a49cdecdaf4065d430c5ffb574b96bfdd29afff6306
Deleted: sha256:54a7e1eaf7406524bb6e9959c77d92c2f561ddc493c395f781d54a89442104c6
Deleted: sha256:65be127d663a47762671e75283e3aff8b5f10f18bee572d5594c02f6c87cc20a
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87b6c8e9de27bde0d30602de328726dd17aac943fe09b031a01d4215fd63e874
  Associated tags:
 - 20230204-083211
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-083211].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:87b6c8e9de27bde0d30602de328726dd17aac943fe09b031a01d4215fd63e874].
$ rm -rf /tmp/tmp.sybwcIZfLc
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:0baeeddbb231be7b1ee1ee5addcdca4257bdbf9a995768576a9702dd9d17ee86].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204082045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:097a470595ef6fe69e07f0ae537b280e8bfb647e61b0e19f59bb3612294423e3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 750886.
Stopping expansion service pid: 750887.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 44s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1248

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1248/display/redirect?page=changes>

Changes:

[noreply] skip automated expansion test (#25304)

[noreply] Add banner highlighting beam ml (#25306)

[noreply] Optimize to use cached output receiver instead of creating one on DoFn

[noreply] Optimize PGBK table to only update cache when there is a large enough

[noreply] Swap setting a context from being on the hot path when we emit elements


------------------------------------------
[...truncated 1.00 MB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-HJzGfpAZr6axkWAxOwDvi2sSrUqEph2DaT_ESKt1TJY.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16654/go-8-1675480817500313279/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-023350"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204022056"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-023350"
      }
    ]
  },
  "name": "go-testxlang_partition-267",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/04 03:20:25 Submitted job: 2023-02-03_19_20_25-8286959551891359932
2023/02/04 03:20:25 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-03_19_20_25-8286959551891359932?project=apache-beam-testing
2023/02/04 03:20:25 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-03_19_20_25-8286959551891359932
2023/02/04 03:20:25 Job state: JOB_STATE_PENDING ...
2023/02/04 03:20:55 Job still running ...
2023/02/04 03:21:25 Job still running ...
2023/02/04 03:21:55 Job still running ...
2023/02/04 03:22:25 Job still running ...
2023/02/04 03:22:56 Job still running ...
2023/02/04 03:23:26 Job still running ...
2023/02/04 03:23:56 Job still running ...
2023/02/04 03:24:26 Job still running ...
2023/02/04 03:24:56 Job still running ...
2023/02/04 03:25:26 Job still running ...
2023/02/04 03:25:56 Job still running ...
2023/02/04 03:26:26 Job still running ...
2023/02/04 03:26:56 Job still running ...
2023/02/04 03:27:26 Job still running ...
2023/02/04 03:27:56 Job still running ...
2023/02/04 03:28:26 Job still running ...
2023/02/04 03:28:56 Job still running ...
2023/02/04 03:29:26 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-03_19_20_25-8286959551891359932 failed
--- FAIL: TestXLang_Partition (579.40s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3330.218s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675478071045847638
--- FAIL: TestBigQueryIO_BasicWriteRead (5.99s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43043 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@usICacUIpT" is_bounded:BOUNDED windowing_strategy_id:"w0@usICacUIpT"}} windowing_strategies:{key:"w0@usICacUIpT" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@usICacUIpT" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@usICacUIpT" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@usICacUIpT" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675478071045847638\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"usICacUIpT"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:43043 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@usICacUIpT" is_bounded:BOUNDED windowing_strategy_id:"w0@usICacUIpT"}} windowing_strategies:{key:"w0@usICacUIpT" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@usICacUIpT" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@usICacUIpT" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@usICacUIpT" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675478071045847638\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"usICacUIpT"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 27 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000308800})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000308800})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004909e0?, 0xc00049c050?}, {0x110f943, 0x39}, {0xc00002c0c0?, 0xa969c0?, 0x1?}, {0xc000401400, 0xf}, 0xc0001b3d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000490980?, 0xc00049c050?}, {0xc00004cc00, 0x52}, {0x1?}, {0xc0001b3ea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000401400, 0xf}, {0xc00004cc00, 0x52}, {0xe96fa0, 0xc0004921d8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000463860)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000463860, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.019s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.049s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:43f45e7d60f844e5248f51a8c5d627482035f8934fa9a27ac04afa4908d6feff
  Associated tags:
 - 20230204-023350
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-023350
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230204-023350].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:43f45e7d60f844e5248f51a8c5d627482035f8934fa9a27ac04afa4908d6feff].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204022056]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ce9c73d7a899ef7ce3b9808cd24c448673ed57fb7ad40ca3a46aad7b90509744]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230204022056] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ce9c73d7a899ef7ce3b9808cd24c448673ed57fb7ad40ca3a46aad7b90509744])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ce9c73d7a899ef7ce3b9808cd24c448673ed57fb7ad40ca3a46aad7b90509744
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ce9c73d7a899ef7ce3b9808cd24c448673ed57fb7ad40ca3a46aad7b90509744].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204022056]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d076630da696c97e06ae83b7b2e0a99526e785cb9a5f7237ce7bbc2772767e62]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230204022056] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d076630da696c97e06ae83b7b2e0a99526e785cb9a5f7237ce7bbc2772767e62])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d076630da696c97e06ae83b7b2e0a99526e785cb9a5f7237ce7bbc2772767e62
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d076630da696c97e06ae83b7b2e0a99526e785cb9a5f7237ce7bbc2772767e62].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 34s
216 actionable tasks: 165 executed, 41 from cache, 10 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1247

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1247/display/redirect?page=changes>

Changes:

[noreply] 24472 Implement FileWriteSchemaTransformProvider (#24806)

[noreply] Embed ML video to docs (#25302)


------------------------------------------
[...truncated 1014.88 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25994/go-8-1675459304259856558/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-203317"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203202109"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-203317"
      }
    ]
  },
  "name": "go-testxlang_partition-944",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/03 21:21:52 Submitted job: 2023-02-03_13_21_52-8683573295370892825
2023/02/03 21:21:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-03_13_21_52-8683573295370892825?project=apache-beam-testing
2023/02/03 21:21:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-03_13_21_52-8683573295370892825
2023/02/03 21:21:52 Job state: JOB_STATE_PENDING ...
2023/02/03 21:22:22 Job still running ...
2023/02/03 21:22:53 Job still running ...
2023/02/03 21:23:23 Job still running ...
2023/02/03 21:23:53 Job still running ...
2023/02/03 21:24:23 Job still running ...
2023/02/03 21:24:53 Job still running ...
2023/02/03 21:25:23 Job still running ...
2023/02/03 21:25:53 Job still running ...
2023/02/03 21:26:23 Job still running ...
2023/02/03 21:26:53 Job still running ...
2023/02/03 21:27:23 Job still running ...
2023/02/03 21:27:53 Job still running ...
2023/02/03 21:28:23 Job still running ...
2023/02/03 21:28:53 Job still running ...
2023/02/03 21:29:23 Job still running ...
2023/02/03 21:29:53 Job still running ...
2023/02/03 21:30:23 Job still running ...
2023/02/03 21:30:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-03_13_21_52-8683573295370892825 failed
--- FAIL: TestXLang_Partition (579.82s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3453.111s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675456438069671434
--- FAIL: TestBigQueryIO_BasicWriteRead (5.31s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40301 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qGhDOmlSZJ" is_bounded:BOUNDED windowing_strategy_id:"w0@qGhDOmlSZJ"}} windowing_strategies:{key:"w0@qGhDOmlSZJ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qGhDOmlSZJ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qGhDOmlSZJ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qGhDOmlSZJ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675456438069671434\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qGhDOmlSZJ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40301 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qGhDOmlSZJ" is_bounded:BOUNDED windowing_strategy_id:"w0@qGhDOmlSZJ"}} windowing_strategies:{key:"w0@qGhDOmlSZJ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qGhDOmlSZJ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qGhDOmlSZJ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qGhDOmlSZJ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675456438069671434\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qGhDOmlSZJ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00002cf40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00002cf40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000468620?, 0xc000138230?}, {0x110f943, 0x39}, {0xc00047c0c0?, 0xa969c0?, 0x1?}, {0xc000043200, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004685c0?, 0xc000138230?}, {0xc00004c540, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043200, 0xf}, {0xc00004c540, 0x52}, {0xe96fa0, 0xc0004902c8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000582d00)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000582d00, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.340s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.032s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.031s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e7c4e4c5032b71efe2decf5c4a494e10e6cfc1a7e63811c500b82ab016e7fc86
  Associated tags:
 - 20230203-203317
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-203317
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-203317].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:e7c4e4c5032b71efe2decf5c4a494e10e6cfc1a7e63811c500b82ab016e7fc86].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203202109]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f6894b478913a246a8f95907c627e97257c7fdeee3a115fac25ab1470072762]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203202109] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f6894b478913a246a8f95907c627e97257c7fdeee3a115fac25ab1470072762])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f6894b478913a246a8f95907c627e97257c7fdeee3a115fac25ab1470072762
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f6894b478913a246a8f95907c627e97257c7fdeee3a115fac25ab1470072762].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203202109]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0ea11fef83c1486bacc95e9ed4286ec319a316689ab7c00cbe65b26e7ce2bcdf]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203202109] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0ea11fef83c1486bacc95e9ed4286ec319a316689ab7c00cbe65b26e7ce2bcdf])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0ea11fef83c1486bacc95e9ed4286ec319a316689ab7c00cbe65b26e7ce2bcdf
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:0ea11fef83c1486bacc95e9ed4286ec319a316689ab7c00cbe65b26e7ce2bcdf].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 47s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1246

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1246/display/redirect?page=changes>

Changes:

[noreply] [Spark Dataset runner] Fix collection encoder bug that may lead to

[noreply] [Spark Dataset runner] Break linage of dataset to reduce Spark planning

[noreply] Fix flaky test due to create bigquery dataset conflict (#25266)


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test20474/go-8-1675437626618338474/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203142050"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329"
      }
    ]
  },
  "name": "go-testxlang_partition-424",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/03 15:20:35 Submitted job: 2023-02-03_07_20_35-15194200630969544463
2023/02/03 15:20:35 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-03_07_20_35-15194200630969544463?project=apache-beam-testing
2023/02/03 15:20:35 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-03_07_20_35-15194200630969544463
2023/02/03 15:20:35 Job state: JOB_STATE_PENDING ...
2023/02/03 15:21:05 Job still running ...
2023/02/03 15:21:35 Job still running ...
2023/02/03 15:22:05 Job still running ...
2023/02/03 15:22:35 Job still running ...
2023/02/03 15:23:05 Job still running ...
2023/02/03 15:23:36 Job still running ...
2023/02/03 15:24:06 Job still running ...
2023/02/03 15:24:36 Job still running ...
2023/02/03 15:25:06 Job still running ...
2023/02/03 15:25:36 Job still running ...
2023/02/03 15:26:06 Job still running ...
2023/02/03 15:26:36 Job still running ...
2023/02/03 15:27:06 Job still running ...
2023/02/03 15:27:36 Job still running ...
2023/02/03 15:28:06 Job still running ...
2023/02/03 15:28:36 Job still running ...
2023/02/03 15:29:06 Job still running ...
2023/02/03 15:29:36 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-03_07_20_35-15194200630969544463 failed
--- FAIL: TestXLang_Partition (580.37s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3360.585s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675434849546772749
--- FAIL: TestBigQueryIO_BasicWriteRead (4.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46119 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@disEmsoFPa" is_bounded:BOUNDED windowing_strategy_id:"w0@disEmsoFPa"}} windowing_strategies:{key:"w0@disEmsoFPa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@disEmsoFPa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@disEmsoFPa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@disEmsoFPa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675434849546772749\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"disEmsoFPa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46119 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@disEmsoFPa" is_bounded:BOUNDED windowing_strategy_id:"w0@disEmsoFPa"}} windowing_strategies:{key:"w0@disEmsoFPa" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@disEmsoFPa" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@disEmsoFPa" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@disEmsoFPa" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675434849546772749\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"disEmsoFPa"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0004d4dc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0004d4dc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000118ba0?, 0xc0001176d0?}, {0x110f943, 0x39}, {0xc0001d2180?, 0xa969c0?, 0x1?}, {0xc000042d40, 0xf}, 0xc0001cdd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000118b40?, 0xc0001176d0?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc0001cdea8, 0x2, 0x7fbabc396dc8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d40, 0xf}, {0xc00004c5a0, 0x52}, {0xe96fa0, 0xc0000a6050})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000583040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000583040, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.895s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.051s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:378d6858b43dc560c9bdbfd2e68c5b5c0a5432f00fc262e87c7b7d80f6e291a4
Deleted: sha256:3ecc045da8e969dacb728d3277f430f51ef344b5a03bc6df0e1276f436887b4e
Deleted: sha256:c5dfceacaad8fbfbea970c43b9d986a28c039eab1e8ebc25559c7e4909e36b58
Deleted: sha256:196751e330fd391b64d236350e7a729e3a42e8f02a2f431980c4740d6bee5051
Deleted: sha256:42cd78ea0d833c95759b9159188a88ecad758107497b05e08dff0930bdd24ded
Deleted: sha256:730e4d53e38bd4dee45ff5f631c3bc60adf1e7f32dc626d15ed6dceab2fed130
Deleted: sha256:758eff5324fc801d7192b9a78292528636a5695fb62b844f84646c3085e542f0
Deleted: sha256:c8c63a8848526cc18ecf78fdb8d1cb5392ba8e7548db2e2773de6bf6c509b546
Deleted: sha256:a5a2aaf60f8d891637c48082d1763d591335962872587106f3b7854713d32245
Deleted: sha256:ee62a8d4acc81bb39944a5880bdf2575bd4c2dbd4e1460906e0836086e2ffde8
Deleted: sha256:42db3d18065ec8225ed72821fea534eab0fc11bf638067b2c4582065afd42c1c
Deleted: sha256:99ca7cd4341cc693d5a373cb743e3a47b6e1f360059ad645051751d779674947
Deleted: sha256:7273da14eb78f2f30f885b6309d11c2d8aeff00b59457676e4a288f4d195c90c
Deleted: sha256:384b070dcf41b7f6aab2a6cbbdb5e3061871bf9be0ac76d6188229bad9742623
Deleted: sha256:c931147481779a9c2d2c63dcd46235431932af24333ff1bba7db109d2bb0f96a
Deleted: sha256:328c874e2c6f688e3901347e3b3e49e4347ef410bb6a8448f9f15fcbe13f2ee5
Deleted: sha256:eeca7f1db9306431bcb973453e9f142b1c06c921b7bca613e31ebafaf2da31e1
Deleted: sha256:0c054a19a491232739e4f07b8874655b6367676821bf328ab6f4b9125f54b56f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:378d6858b43dc560c9bdbfd2e68c5b5c0a5432f00fc262e87c7b7d80f6e291a4
  Associated tags:
 - 20230203-143329
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-143329].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:378d6858b43dc560c9bdbfd2e68c5b5c0a5432f00fc262e87c7b7d80f6e291a4].
$ rm -rf /tmp/tmp.jHTGPhYuEE
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4e8479615a534f3028f9a60d21a4768e4d34d0b892c13a6fe3a4018dcca71c3b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203142050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203142050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203142050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:dfed831b6308d0040757bc2d2b54b9d33ce2eaa67060204d90b67e1988e32c1d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3099024.
Stopping expansion service pid: 3099025.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 43s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1245

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1245/display/redirect>

Changes:


------------------------------------------
[...truncated 1009.85 KB...]
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test26606/go-8-1675416018764272018/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-083410"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203082058"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-083410"
      }
    ]
  },
  "name": "go-testxlang_partition-760",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/03 09:20:27 Submitted job: 2023-02-03_01_20_26-3794808748344182708
2023/02/03 09:20:27 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-03_01_20_26-3794808748344182708?project=apache-beam-testing
2023/02/03 09:20:27 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-03_01_20_26-3794808748344182708
2023/02/03 09:20:27 Job state: JOB_STATE_PENDING ...
2023/02/03 09:20:57 Job still running ...
2023/02/03 09:21:27 Job still running ...
2023/02/03 09:21:57 Job still running ...
2023/02/03 09:22:27 Job still running ...
2023/02/03 09:22:57 Job still running ...
2023/02/03 09:23:27 Job still running ...
2023/02/03 09:23:57 Job still running ...
2023/02/03 09:24:27 Job still running ...
2023/02/03 09:24:57 Job still running ...
2023/02/03 09:25:27 Job still running ...
2023/02/03 09:25:57 Job still running ...
2023/02/03 09:26:27 Job still running ...
2023/02/03 09:26:57 Job still running ...
2023/02/03 09:27:28 Job still running ...
2023/02/03 09:27:58 Job still running ...
2023/02/03 09:28:28 Job still running ...
2023/02/03 09:28:58 Job still running ...
2023/02/03 09:29:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-03_01_20_26-3794808748344182708 failed
--- FAIL: TestXLang_Partition (579.85s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3311.911s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675413289855675245
--- FAIL: TestBigQueryIO_BasicWriteRead (4.92s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44089 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wBIXPlLASA" is_bounded:BOUNDED windowing_strategy_id:"w0@wBIXPlLASA"}} windowing_strategies:{key:"w0@wBIXPlLASA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wBIXPlLASA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wBIXPlLASA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wBIXPlLASA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675413289855675245\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wBIXPlLASA"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44089 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wBIXPlLASA" is_bounded:BOUNDED windowing_strategy_id:"w0@wBIXPlLASA"}} windowing_strategies:{key:"w0@wBIXPlLASA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wBIXPlLASA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wBIXPlLASA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wBIXPlLASA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675413289855675245\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wBIXPlLASA"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000462d40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000462d40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480580?, 0xc000148000?}, {0x110f943, 0x39}, {0xc0000ee180?, 0xa969c0?, 0x1?}, {0xc00011cd80, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480520?, 0xc000148000?}, {0xc00004c9c0, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00011cd80, 0xf}, {0xc00004c9c0, 0x52}, {0xe96fa0, 0xc0003f80c8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000581380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000581380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.953s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.040s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.043s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8e5a01a5aa313525dcec5978797836965b5920809e7284db8723a81a00e80106
  Associated tags:
 - 20230203-083410
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-083410
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-083410].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:8e5a01a5aa313525dcec5978797836965b5920809e7284db8723a81a00e80106].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203082058]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3bf0e7e437f22072b6786f54ba80d6b29720b4e0c82342572b598e01cb5ea1d1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203082058] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3bf0e7e437f22072b6786f54ba80d6b29720b4e0c82342572b598e01cb5ea1d1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3bf0e7e437f22072b6786f54ba80d6b29720b4e0c82342572b598e01cb5ea1d1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:3bf0e7e437f22072b6786f54ba80d6b29720b4e0c82342572b598e01cb5ea1d1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203082058]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2a37be204f2e28eb07e3e408fe936e23528b486a2798bd1332c812fb495ca660]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203082058] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2a37be204f2e28eb07e3e408fe936e23528b486a2798bd1332c812fb495ca660])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2a37be204f2e28eb07e3e408fe936e23528b486a2798bd1332c812fb495ca660
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:2a37be204f2e28eb07e3e408fe936e23528b486a2798bd1332c812fb495ca660].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 34s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
Publishing build scan failed due to network error 'java.net.SocketException: Unexpected end of file from server' (2 retries remaining)...
Publishing build scan failed due to network error 'java.net.SocketException: Unexpected end of file from server' (1 retry remaining)...

A network error occurred.

If you require assistance with this problem, please report it via https://gradle.com/help/plugin and include the following information via copy/paste.

----------
Gradle version: 7.5.1
Plugin version: 3.4.1
Request URL: https://status.gradle.com
Request ID: 16e7c7e9-c06b-44f9-9e8a-d132e1015333
Exception: java.net.SocketException: Unexpected end of file from server
----------

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1244

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1244/display/redirect?page=changes>

Changes:

[noreply] [CdapIO] Implement windowed write (#25206)


------------------------------------------
[...truncated 1005.37 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32293/go-8-1675394324249189702/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-023237"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203022053"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-023237"
      }
    ]
  },
  "name": "go-testxlang_partition-245",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/03 03:18:53 Submitted job: 2023-02-02_19_18_52-3893925768942610999
2023/02/03 03:18:53 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-02_19_18_52-3893925768942610999?project=apache-beam-testing
2023/02/03 03:18:53 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-02_19_18_52-3893925768942610999
2023/02/03 03:18:53 Job state: JOB_STATE_PENDING ...
2023/02/03 03:19:23 Job still running ...
2023/02/03 03:19:53 Job still running ...
2023/02/03 03:20:23 Job still running ...
2023/02/03 03:20:53 Job still running ...
2023/02/03 03:21:23 Job still running ...
2023/02/03 03:21:53 Job still running ...
2023/02/03 03:22:23 Job still running ...
2023/02/03 03:22:53 Job still running ...
2023/02/03 03:23:23 Job still running ...
2023/02/03 03:23:53 Job still running ...
2023/02/03 03:24:23 Job still running ...
2023/02/03 03:24:54 Job still running ...
2023/02/03 03:25:24 Job still running ...
2023/02/03 03:25:54 Job still running ...
2023/02/03 03:26:24 Job still running ...
2023/02/03 03:26:54 Job still running ...
2023/02/03 03:27:24 Job still running ...
2023/02/03 03:27:54 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-02_19_18_52-3893925768942610999 failed
--- FAIL: TestXLang_Partition (580.50s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3312.820s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675391595105107684
--- FAIL: TestBigQueryIO_BasicWriteRead (4.57s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34635 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YJQwYKpRvl" is_bounded:BOUNDED windowing_strategy_id:"w0@YJQwYKpRvl"}} windowing_strategies:{key:"w0@YJQwYKpRvl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YJQwYKpRvl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YJQwYKpRvl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YJQwYKpRvl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675391595105107684\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YJQwYKpRvl"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34635 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@YJQwYKpRvl" is_bounded:BOUNDED windowing_strategy_id:"w0@YJQwYKpRvl"}} windowing_strategies:{key:"w0@YJQwYKpRvl" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@YJQwYKpRvl" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@YJQwYKpRvl" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@YJQwYKpRvl" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675391595105107684\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"YJQwYKpRvl"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0006682c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0006682c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7140?, 0xc0000bc8c0?}, {0x110f943, 0x39}, {0xc0000f00c0?, 0xa969c0?, 0x1?}, {0xc000122dd0, 0xf}, 0xc0006edd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a70e0?, 0xc0000bc8c0?}, {0xc000686360, 0x52}, {0x1?}, {0xc0006edea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000122dd0, 0xf}, {0xc000686360, 0x52}, {0xe96fa0, 0xc0003f87a8})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00045d380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00045d380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.605s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.038s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d5ede7910151b3defcc1a0f18429d752296a73655449fefe4ff0bb65d63bee2f
  Associated tags:
 - 20230203-023237
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-023237
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230203-023237].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:d5ede7910151b3defcc1a0f18429d752296a73655449fefe4ff0bb65d63bee2f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203022053]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d6684536665b085a807ab39335bb8a87219c51db5219854607e2a4924a43a0e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230203022053] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d6684536665b085a807ab39335bb8a87219c51db5219854607e2a4924a43a0e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d6684536665b085a807ab39335bb8a87219c51db5219854607e2a4924a43a0e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7d6684536665b085a807ab39335bb8a87219c51db5219854607e2a4924a43a0e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203022053]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8595554b8838b31049fec6752f6a6f38101a95c0f6089a1fc42cb651d6e4122]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230203022053] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8595554b8838b31049fec6752f6a6f38101a95c0f6089a1fc42cb651d6e4122])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8595554b8838b31049fec6752f6a6f38101a95c0f6089a1fc42cb651d6e4122
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d8595554b8838b31049fec6752f6a6f38101a95c0f6089a1fc42cb651d6e4122].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 1s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1243

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1243/display/redirect?page=changes>

Changes:

[noreply] Add sideinputs to the RunInference Transform (#25200)

[noreply] Move changes to correct release in CHANGES.md (#25288)

[noreply] Pass instead of raising an error (#25287)

[noreply] [WebSite] Add new Python quickstart (#24804)


------------------------------------------
[...truncated 1012.02 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test29375/go-8-1675372841967942486/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-203254"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202202049"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-203254"
      }
    ]
  },
  "name": "go-testxlang_partition-49",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/02 21:20:51 Submitted job: 2023-02-02_13_20_49-11260245737338200725
2023/02/02 21:20:51 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-02_13_20_49-11260245737338200725?project=apache-beam-testing
2023/02/02 21:20:51 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-02_13_20_49-11260245737338200725
2023/02/02 21:20:51 Job state: JOB_STATE_PENDING ...
2023/02/02 21:21:21 Job still running ...
2023/02/02 21:21:51 Job still running ...
2023/02/02 21:22:21 Job still running ...
2023/02/02 21:22:51 Job still running ...
2023/02/02 21:23:22 Job still running ...
2023/02/02 21:23:52 Job still running ...
2023/02/02 21:24:22 Job still running ...
2023/02/02 21:24:52 Job still running ...
2023/02/02 21:25:22 Job still running ...
2023/02/02 21:25:52 Job still running ...
2023/02/02 21:26:22 Job still running ...
2023/02/02 21:26:52 Job still running ...
2023/02/02 21:27:23 Job still running ...
2023/02/02 21:27:53 Job still running ...
2023/02/02 21:28:23 Job still running ...
2023/02/02 21:28:53 Job still running ...
2023/02/02 21:29:23 Job still running ...
2023/02/02 21:29:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-02_13_20_49-11260245737338200725 failed
--- FAIL: TestXLang_Partition (581.58s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3416.130s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675370010525602305
--- FAIL: TestBigQueryIO_BasicWriteRead (4.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40787 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qzvVwYEiqK" is_bounded:BOUNDED windowing_strategy_id:"w0@qzvVwYEiqK"}} windowing_strategies:{key:"w0@qzvVwYEiqK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qzvVwYEiqK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qzvVwYEiqK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qzvVwYEiqK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675370010525602305\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qzvVwYEiqK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40787 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@qzvVwYEiqK" is_bounded:BOUNDED windowing_strategy_id:"w0@qzvVwYEiqK"}} windowing_strategies:{key:"w0@qzvVwYEiqK" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@qzvVwYEiqK" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@qzvVwYEiqK" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@qzvVwYEiqK" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675370010525602305\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"qzvVwYEiqK"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 29 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00024da40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00024da40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6fa0?, 0xc00068d680?}, {0x110f943, 0x39}, {0xc00017e000?, 0xa969c0?, 0x1?}, {0xc0003f2ec0, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f40?, 0xc00068d680?}, {0xc000118840, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f5a58019800?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f2ec0, 0xf}, {0xc000118840, 0x52}, {0xe96fa0, 0xc000136cd0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000335520)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000335520, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.413s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5dc0c9714cedad8cddea2d62d62ddfbb0e64f91975641006cae2f7fd8e6fbdb3
  Associated tags:
 - 20230202-203254
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-203254
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-203254].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:5dc0c9714cedad8cddea2d62d62ddfbb0e64f91975641006cae2f7fd8e6fbdb3].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202202049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1dabc05438c3d6a5c82bf90ff1b39602c03142d434302d459358f3a8ce5e84b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202202049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1dabc05438c3d6a5c82bf90ff1b39602c03142d434302d459358f3a8ce5e84b])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1dabc05438c3d6a5c82bf90ff1b39602c03142d434302d459358f3a8ce5e84b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:e1dabc05438c3d6a5c82bf90ff1b39602c03142d434302d459358f3a8ce5e84b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202202049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6f152087b436d374f9991d7712c6d687417ee14c637867f05cd3aac3fcbb700]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202202049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6f152087b436d374f9991d7712c6d687417ee14c637867f05cd3aac3fcbb700])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6f152087b436d374f9991d7712c6d687417ee14c637867f05cd3aac3fcbb700
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6f152087b436d374f9991d7712c6d687417ee14c637867f05cd3aac3fcbb700].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 10m 1s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1242

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1242/display/redirect?page=changes>

Changes:

[noreply] [Spark Runner] Add new experiment that provides concurrent bounded


------------------------------------------
[...truncated 1010.94 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-1xZcWSzAdY-zBHSmaLlxUKQf-WSD8oxKD82_vpNKAiQ.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15054/go-8-1675351127372355784/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-143250"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202142049"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-143250"
      }
    ]
  },
  "name": "go-testxlang_partition-345",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/02 15:18:57 Submitted job: 2023-02-02_07_18_56-17478133495707220586
2023/02/02 15:18:57 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-02_07_18_56-17478133495707220586?project=apache-beam-testing
2023/02/02 15:18:57 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-02_07_18_56-17478133495707220586
2023/02/02 15:18:57 Job state: JOB_STATE_PENDING ...
2023/02/02 15:19:27 Job still running ...
2023/02/02 15:19:57 Job still running ...
2023/02/02 15:20:27 Job still running ...
2023/02/02 15:20:57 Job still running ...
2023/02/02 15:21:27 Job still running ...
2023/02/02 15:21:57 Job still running ...
2023/02/02 15:22:27 Job still running ...
2023/02/02 15:22:57 Job still running ...
2023/02/02 15:23:27 Job still running ...
2023/02/02 15:23:57 Job still running ...
2023/02/02 15:24:28 Job still running ...
2023/02/02 15:24:58 Job still running ...
2023/02/02 15:25:28 Job still running ...
2023/02/02 15:25:58 Job still running ...
2023/02/02 15:26:28 Job still running ...
2023/02/02 15:26:58 Job still running ...
2023/02/02 15:27:28 Job still running ...
2023/02/02 15:27:58 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-02_07_18_56-17478133495707220586 failed
--- FAIL: TestXLang_Partition (581.44s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3306.198s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675348405807095318
--- FAIL: TestBigQueryIO_BasicWriteRead (4.43s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42229 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@TNyVZeVSiO" is_bounded:BOUNDED windowing_strategy_id:"w0@TNyVZeVSiO"}} windowing_strategies:{key:"w0@TNyVZeVSiO" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@TNyVZeVSiO" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@TNyVZeVSiO" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@TNyVZeVSiO" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675348405807095318\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"TNyVZeVSiO"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42229 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@TNyVZeVSiO" is_bounded:BOUNDED windowing_strategy_id:"w0@TNyVZeVSiO"}} windowing_strategies:{key:"w0@TNyVZeVSiO" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@TNyVZeVSiO" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@TNyVZeVSiO" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@TNyVZeVSiO" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675348405807095318\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"TNyVZeVSiO"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 34 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0001206c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0001206c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a78e0?, 0xc000125c20?}, {0x110f943, 0x39}, {0xc0001700c0?, 0xa969c0?, 0x1?}, {0xc00010f590, 0xf}, 0xc00002dd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7880?, 0xc000125c20?}, {0xc00004c9c0, 0x52}, {0x1?}, {0xc00002dea8, 0x2, 0x7fd21b73dae8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00010f590, 0xf}, {0xc00004c9c0, 0x52}, {0xe96fa0, 0xc0000328a0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001029c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001029c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.490s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3236c262abae77d2ddebb42ffde4dee086c11cd591cea9c09dd81b2096a66294
  Associated tags:
 - 20230202-143250
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-143250
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-143250].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3236c262abae77d2ddebb42ffde4dee086c11cd591cea9c09dd81b2096a66294].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202142049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b81967f9170dcff9c42506f80ca343a50b2109465ef19c102ae20cdc59cc378c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202142049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b81967f9170dcff9c42506f80ca343a50b2109465ef19c102ae20cdc59cc378c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b81967f9170dcff9c42506f80ca343a50b2109465ef19c102ae20cdc59cc378c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b81967f9170dcff9c42506f80ca343a50b2109465ef19c102ae20cdc59cc378c].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202142049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c17ad74f0fb559baf2addc6d1bfff1a6bcd9552ef683965359494beeccc3b2e1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202142049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c17ad74f0fb559baf2addc6d1bfff1a6bcd9552ef683965359494beeccc3b2e1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c17ad74f0fb559baf2addc6d1bfff1a6bcd9552ef683965359494beeccc3b2e1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c17ad74f0fb559baf2addc6d1bfff1a6bcd9552ef683965359494beeccc3b2e1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 5s
216 actionable tasks: 153 executed, 51 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1241

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1241/display/redirect?page=changes>

Changes:

[noreply] Bump github.com/aws/aws-sdk-go-v2/feature/s3/manager in /sdks (#25270)


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5781/go-8-1675329523532448067/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202082047"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225"
      }
    ]
  },
  "name": "go-testxlang_partition-726",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/02 09:18:52 Submitted job: 2023-02-02_01_18_52-8489686547433244593
2023/02/02 09:18:52 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-02_01_18_52-8489686547433244593?project=apache-beam-testing
2023/02/02 09:18:52 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-02_01_18_52-8489686547433244593
2023/02/02 09:18:52 Job state: JOB_STATE_PENDING ...
2023/02/02 09:19:23 Job still running ...
2023/02/02 09:19:53 Job still running ...
2023/02/02 09:20:23 Job still running ...
2023/02/02 09:20:53 Job still running ...
2023/02/02 09:21:23 Job still running ...
2023/02/02 09:21:53 Job still running ...
2023/02/02 09:22:23 Job still running ...
2023/02/02 09:22:53 Job still running ...
2023/02/02 09:23:23 Job still running ...
2023/02/02 09:23:53 Job still running ...
2023/02/02 09:24:23 Job still running ...
2023/02/02 09:24:53 Job still running ...
2023/02/02 09:25:23 Job still running ...
2023/02/02 09:25:53 Job still running ...
2023/02/02 09:26:23 Job still running ...
2023/02/02 09:26:53 Job still running ...
2023/02/02 09:27:23 Job still running ...
2023/02/02 09:27:53 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-02_01_18_52-8489686547433244593 failed
--- FAIL: TestXLang_Partition (580.65s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3325.144s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675326782170937701
--- FAIL: TestBigQueryIO_BasicWriteRead (4.43s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46859 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@bPEeEXMOCr" is_bounded:BOUNDED windowing_strategy_id:"w0@bPEeEXMOCr"}} windowing_strategies:{key:"w0@bPEeEXMOCr" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@bPEeEXMOCr" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@bPEeEXMOCr" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@bPEeEXMOCr" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675326782170937701\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"bPEeEXMOCr"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46859 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@bPEeEXMOCr" is_bounded:BOUNDED windowing_strategy_id:"w0@bPEeEXMOCr"}} windowing_strategies:{key:"w0@bPEeEXMOCr" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@bPEeEXMOCr" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@bPEeEXMOCr" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@bPEeEXMOCr" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675326782170937701\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"bPEeEXMOCr"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 8 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00002b240})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00002b240})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004844c0?, 0xc0005a2000?}, {0x110f943, 0x39}, {0xc00015e180?, 0xa969c0?, 0x1?}, {0xc0003f0e30, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000484460?, 0xc0005a2000?}, {0xc000118840, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f0848c46ad0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f0e30, 0xf}, {0xc000118840, 0x52}, {0xe96fa0, 0xc000486170})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004929c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004929c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.468s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.037s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2baec754d29cd095f71c0e8d2f5f80675da459e614ee3af81cef8c97762183cd
Deleted: sha256:ee1e70e7dc7b472dbcd911be9046f89f56a8740c269e3fd5ae66365377084484
Deleted: sha256:e6e15b398bfab3ef49b0cb94d465765b7edabfb3e7ceb118da66a1783b4af189
Deleted: sha256:48a134f6d568616709ec707a94c6f8fe802946037da8b3ef19a296c77f084d98
Deleted: sha256:590df18df3c2e1be479eb607cc2b7ecf1f28542b3d6642d54a51b9d6447bf9d4
Deleted: sha256:0b978de551eecd95df40fa3131fab2f815fb1c9e6e78256b408e9f16d4911076
Deleted: sha256:688c3e7a1e2001c64cd41d97b8fea8dbeef9f0b1a43c5d51ce76087b501f8e5d
Deleted: sha256:ab25a220f9da4d6efb8e9489775467f451b35557cbcfaaaf350e2e8f118f30f8
Deleted: sha256:e2c9e979b24e71de43517e412efe1e6012a68f1bb0c1fd613e009e1ae5d54f13
Deleted: sha256:4cde23f2634e62c8c718aef277dc4b221c8d8f7aa3a76b7a42e2a0c5f5f29d8d
Deleted: sha256:f49e9c58f4e23818952a78b84ca4b9e6b39e9b921e42eb4d9c5260fe5b4557d6
Deleted: sha256:1205e8393063759971c30762e2f1ad5c9e71c3d6ed25e381765166df7b749106
Deleted: sha256:71c878a29e95a3ab7d0bc7d0c0f4e786692b433860c3371c13e0a22fb4f3fab5
Deleted: sha256:4949d0eda6c864e40c28f7bc4ffe9567b13bfbe2d20f81cd4970ac4af11aa3c8
Deleted: sha256:d15a1664ccb1c183ac000d5b22d8cdaadb06169c77fb1c6524a019d964b3d3fb
Deleted: sha256:c0b36dbc9d17c824696dc356e8bd74b4b1f44d77f9a463687ac51e9d26b708f0
Deleted: sha256:fa24403ad2586955a8671dcfec1f88d0b88ec50b4208343d54f04ce9aab8bbf1
Deleted: sha256:8d7d78d108a17215d9bd6611272f56c3790a882170459e30d5d543bee2f34482
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2baec754d29cd095f71c0e8d2f5f80675da459e614ee3af81cef8c97762183cd
  Associated tags:
 - 20230202-083225
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-083225].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:2baec754d29cd095f71c0e8d2f5f80675da459e614ee3af81cef8c97762183cd].
$ rm -rf /tmp/tmp.Pj79YMJIzw
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202082047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202082047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202082047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:8f3bd1bab11908e07311d9d4f62d254e1bd11d2e1435e7e66153658385e9729a].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202082047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202082047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202082047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:744c4a0c220c06e915fe9cd464aa4c23ae9e3af2333152101393fcb3aeb394e7].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1720692.
Stopping expansion service pid: 1720693.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 1s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1240

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1240/display/redirect>

Changes:


------------------------------------------
[...truncated 1013.77 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test28563/go-8-1675307984603189607/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-023257"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202022049"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-023257"
      }
    ]
  },
  "name": "go-testxlang_partition-590",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/02 03:19:53 Submitted job: 2023-02-01_19_19_52-17881061529482151702
2023/02/02 03:19:53 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-01_19_19_52-17881061529482151702?project=apache-beam-testing
2023/02/02 03:19:53 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-01_19_19_52-17881061529482151702
2023/02/02 03:19:53 Job state: JOB_STATE_PENDING ...
2023/02/02 03:20:23 Job still running ...
2023/02/02 03:20:53 Job still running ...
2023/02/02 03:21:23 Job still running ...
2023/02/02 03:21:53 Job still running ...
2023/02/02 03:22:23 Job still running ...
2023/02/02 03:22:53 Job still running ...
2023/02/02 03:23:23 Job still running ...
2023/02/02 03:23:53 Job still running ...
2023/02/02 03:24:23 Job still running ...
2023/02/02 03:24:53 Job still running ...
2023/02/02 03:25:23 Job still running ...
2023/02/02 03:25:54 Job still running ...
2023/02/02 03:26:24 Job still running ...
2023/02/02 03:26:54 Job still running ...
2023/02/02 03:27:24 Job still running ...
2023/02/02 03:27:54 Job still running ...
2023/02/02 03:28:24 Job still running ...
2023/02/02 03:28:54 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-01_19_19_52-17881061529482151702 failed
--- FAIL: TestXLang_Partition (580.04s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3352.714s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675305215103211885
--- FAIL: TestBigQueryIO_BasicWriteRead (4.45s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38209 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FWJFmbuCcp" is_bounded:BOUNDED windowing_strategy_id:"w0@FWJFmbuCcp"}} windowing_strategies:{key:"w0@FWJFmbuCcp" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FWJFmbuCcp" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FWJFmbuCcp" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FWJFmbuCcp" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675305215103211885\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FWJFmbuCcp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38209 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@FWJFmbuCcp" is_bounded:BOUNDED windowing_strategy_id:"w0@FWJFmbuCcp"}} windowing_strategies:{key:"w0@FWJFmbuCcp" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@FWJFmbuCcp" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@FWJFmbuCcp" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@FWJFmbuCcp" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675305215103211885\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"FWJFmbuCcp"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 66 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0000c7040})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0000c7040})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048ed20?, 0xc000115ae0?}, {0x110f943, 0x39}, {0xc0001e0000?, 0xa969c0?, 0x1?}, {0xc00048ac90, 0xf}, 0xc000157d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048ecc0?, 0xc000115ae0?}, {0xc00065a300, 0x52}, {0x1?}, {0xc000157ea8, 0x2, 0x7f413a49f580?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048ac90, 0xf}, {0xc00065a300, 0x52}, {0xe96fa0, 0xc00048bfa0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000335380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000335380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.491s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.035s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3cbd2c4441fe68b066103a34b0ed8dc784754fbea75e0ca22efd16960e5d362f
  Associated tags:
 - 20230202-023257
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-023257
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230202-023257].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:3cbd2c4441fe68b066103a34b0ed8dc784754fbea75e0ca22efd16960e5d362f].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bdb5e9cbb9804dc85dadb759050b8695bccb4df1b254ef5cb2f85164704c36d4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230202022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bdb5e9cbb9804dc85dadb759050b8695bccb4df1b254ef5cb2f85164704c36d4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bdb5e9cbb9804dc85dadb759050b8695bccb4df1b254ef5cb2f85164704c36d4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:bdb5e9cbb9804dc85dadb759050b8695bccb4df1b254ef5cb2f85164704c36d4].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8d24b15887eed7a4cd8f6b6c00d45900134864b413a1b988ee450c99732d77e0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230202022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8d24b15887eed7a4cd8f6b6c00d45900134864b413a1b988ee450c99732d77e0])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8d24b15887eed7a4cd8f6b6c00d45900134864b413a1b988ee450c99732d77e0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8d24b15887eed7a4cd8f6b6c00d45900134864b413a1b988ee450c99732d77e0].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 2s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/7zcyhzldiqvsc

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1239

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1239/display/redirect?page=changes>

Changes:

[noreply] Update/add torch versions to tox.ini (#25045)

[noreply] Add support for templates in task hints (#25214)

[noreply] Bump torch (#25057)

[noreply] Fix XVR_Direct time out (#25247)

[noreply] Exclude changestream integration test on DataflowLegacyWorker (#25239)

[noreply] [Tour of Beam] [Task] Fix dependency management for 2.44 Playground java


------------------------------------------
[...truncated 1.01 MB...]
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21080/go-8-1675286465953878008/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201202050"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437"
      }
    ]
  },
  "name": "go-testxlang_partition-302",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/01 21:21:14 Submitted job: 2023-02-01_13_21_14-5849061124377008747
2023/02/01 21:21:14 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-01_13_21_14-5849061124377008747?project=apache-beam-testing
2023/02/01 21:21:14 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-01_13_21_14-5849061124377008747
2023/02/01 21:21:14 Job state: JOB_STATE_PENDING ...
2023/02/01 21:21:45 Job still running ...
2023/02/01 21:22:15 Job still running ...
2023/02/01 21:22:45 Job still running ...
2023/02/01 21:23:15 Job still running ...
2023/02/01 21:23:45 Job still running ...
2023/02/01 21:24:15 Job still running ...
2023/02/01 21:24:45 Job still running ...
2023/02/01 21:25:15 Job still running ...
2023/02/01 21:25:45 Job still running ...
2023/02/01 21:26:15 Job still running ...
2023/02/01 21:26:45 Job still running ...
2023/02/01 21:27:15 Job still running ...
2023/02/01 21:27:45 Job still running ...
2023/02/01 21:28:15 Job still running ...
2023/02/01 21:28:45 Job still running ...
2023/02/01 21:29:15 Job still running ...
2023/02/01 21:29:45 Job still running ...
2023/02/01 21:30:15 Job still running ...
2023/02/01 21:30:46 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-01_13_21_14-5849061124377008747 failed
--- FAIL: TestXLang_Partition (610.42s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3364.091s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675283715406740019
--- FAIL: TestBigQueryIO_BasicWriteRead (4.84s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46683 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@svyIPVBlfe" is_bounded:BOUNDED windowing_strategy_id:"w0@svyIPVBlfe"}} windowing_strategies:{key:"w0@svyIPVBlfe" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@svyIPVBlfe" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@svyIPVBlfe" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@svyIPVBlfe" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675283715406740019\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"svyIPVBlfe"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46683 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@svyIPVBlfe" is_bounded:BOUNDED windowing_strategy_id:"w0@svyIPVBlfe"}} windowing_strategies:{key:"w0@svyIPVBlfe" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@svyIPVBlfe" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@svyIPVBlfe" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@svyIPVBlfe" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675283715406740019\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"svyIPVBlfe"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 54 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00025d7c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00025d7c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000480700?, 0xc0004a8050?}, {0x110f943, 0x39}, {0xc0006660c0?, 0xa969c0?, 0x1?}, {0xc00049cca0, 0xf}, 0xc0000e9d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004806a0?, 0xc0004a8050?}, {0xc0005904e0, 0x52}, {0x1?}, {0xc0000e9ea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00049cca0, 0xf}, {0xc0005904e0, 0x52}, {0xe96fa0, 0xc0003f8128})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.874s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.037s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1c7b7b8f75ee17fc5da8ad576e53c49b7963f119eaf826b9593d04be5fb42f19
Deleted: sha256:03eba54c37f714f970eeba6327ee2f557331b6140c8e36d69f3ca9b0abcb0a40
Deleted: sha256:8887fe5a1ed691c1a2133cb977402b997c134e05ed870208385bbd472d8af291
Deleted: sha256:3507c0550cbd8f5c9a2f74cfc80fc833a22418d39839131b31820cf1598ddc28
Deleted: sha256:744e0f1e6339cef43acce80d45f9e4c554a719dcc29415f269d1c84e1bafe981
Deleted: sha256:f5268b0d8e872be5eece0736a023c688b991af757b41cc0a799bfba95248c920
Deleted: sha256:7aea40e3cdb4489f3e1a346c84595e14dd70476e15e7390c241124c4875d9dcb
Deleted: sha256:8ebb0ad7fb9d6e5eb2f80bd3f4c33bf28fae172ddfcd4a9c7ff733fef222da06
Deleted: sha256:7aff9a2d66c57a23fec67911668266e8042c5b0b3e89f52f5809dde26fb11d1d
Deleted: sha256:6cea3dfe3a68ad61daa6b9e5c04578738211eab5646cba765719c795c2efdf54
Deleted: sha256:0e9c3c35b0ef569a850979b10ba46510792e3ccffd9d42684a64790330ca2a40
Deleted: sha256:097fb50b5a26bb69b1027d1927a09efb133ff8052c20950aeed75f604a76d18d
Deleted: sha256:c0f3b5fc0ccd975df9d78a00fae236c19aa04559b60da30b865af0123769f271
Deleted: sha256:99d502738f3c335c4cf8e4126775ce270432dd7ae17985df1365537c1929f552
Deleted: sha256:908cad5828f9f420a62126b0ee051916d829b92fb79187e5afde76923d69770c
Deleted: sha256:665b44c38703952aac5207c75b271231afbfcb06e9b8bc29fe17e05232b8c1f6
Deleted: sha256:aa1d41f2bafbdf9ae9e5ff50c8ae0eef83a958115ef5cb4d7d616cf4516757de
Deleted: sha256:40d41820903617d77c1497e221fab24371c70db7a329955b7181f07145c894cf
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1c7b7b8f75ee17fc5da8ad576e53c49b7963f119eaf826b9593d04be5fb42f19
  Associated tags:
 - 20230201-203437
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-203437].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1c7b7b8f75ee17fc5da8ad576e53c49b7963f119eaf826b9593d04be5fb42f19].
$ rm -rf /tmp/tmp.BZBVLg8sgF
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201202050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201202050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201202050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ed8ca54915325f3ebeaea82500f5de7273f46b3848f244f55009c46740343bb6].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201202050
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201202050]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201202050] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:de9e3346ce8dd7fe7d2b1219048b158aa63e1e107e10663dec2b49496486e562].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1387643.
Stopping expansion service pid: 1387644.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 11m 18s
216 actionable tasks: 148 executed, 56 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1238

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1238/display/redirect>

Changes:


------------------------------------------
[...truncated 1012.75 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test17851/go-8-1675264717033074957/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201142048"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-143219"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-143219"
      }
    ]
  },
  "name": "go-testxlang_partition-614",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/01 15:18:46 Submitted job: 2023-02-01_07_18_46-14681335251981967726
2023/02/01 15:18:46 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-01_07_18_46-14681335251981967726?project=apache-beam-testing
2023/02/01 15:18:46 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-01_07_18_46-14681335251981967726
2023/02/01 15:18:46 Job state: JOB_STATE_PENDING ...
2023/02/01 15:19:17 Job still running ...
2023/02/01 15:19:47 Job still running ...
2023/02/01 15:20:17 Job still running ...
2023/02/01 15:20:47 Job still running ...
2023/02/01 15:21:17 Job still running ...
2023/02/01 15:21:47 Job still running ...
2023/02/01 15:22:17 Job still running ...
2023/02/01 15:22:47 Job still running ...
2023/02/01 15:23:17 Job still running ...
2023/02/01 15:23:47 Job still running ...
2023/02/01 15:24:17 Job still running ...
2023/02/01 15:24:47 Job still running ...
2023/02/01 15:25:17 Job still running ...
2023/02/01 15:25:47 Job still running ...
2023/02/01 15:26:17 Job still running ...
2023/02/01 15:26:47 Job still running ...
2023/02/01 15:27:17 Job still running ...
2023/02/01 15:27:48 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-01_07_18_46-14681335251981967726 failed
--- FAIL: TestXLang_Partition (581.29s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3326.613s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675261974779816979
--- FAIL: TestBigQueryIO_BasicWriteRead (4.24s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36975 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cNYpIiYPXg" is_bounded:BOUNDED windowing_strategy_id:"w0@cNYpIiYPXg"}} windowing_strategies:{key:"w0@cNYpIiYPXg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cNYpIiYPXg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cNYpIiYPXg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cNYpIiYPXg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675261974779816979\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cNYpIiYPXg"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36975 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@cNYpIiYPXg" is_bounded:BOUNDED windowing_strategy_id:"w0@cNYpIiYPXg"}} windowing_strategies:{key:"w0@cNYpIiYPXg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@cNYpIiYPXg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@cNYpIiYPXg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@cNYpIiYPXg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675261974779816979\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"cNYpIiYPXg"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 29 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0004d6480})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0004d6480})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6f60?, 0xc000117ae0?}, {0x110f943, 0x39}, {0xc0001e0000?, 0xa969c0?, 0x1?}, {0xc000042d80, 0xf}, 0xc000033d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6f00?, 0xc000117ae0?}, {0xc00004c5a0, 0x52}, {0x1?}, {0xc000033ea8, 0x2, 0x7f0228635748?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000042d80, 0xf}, {0xc00004c5a0, 0x52}, {0xe96fa0, 0xc00015a090})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ca9c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ca9c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.269s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:716a4e4a412bb543f19fc2184dddf1c7fe2c4876dea8667efb0cf8c82781a97a
  Associated tags:
 - 20230201-143219
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-143219
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-143219].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:716a4e4a412bb543f19fc2184dddf1c7fe2c4876dea8667efb0cf8c82781a97a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201142048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7cc678c6539ce1415195f73326c0545c1651f2e14b5680e452f24007429243f5]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201142048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7cc678c6539ce1415195f73326c0545c1651f2e14b5680e452f24007429243f5])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7cc678c6539ce1415195f73326c0545c1651f2e14b5680e452f24007429243f5
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7cc678c6539ce1415195f73326c0545c1651f2e14b5680e452f24007429243f5].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201142048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50b10c5726c5de35359d8d8c1f8eac72496e26870cacbb4900371f647fe5ae09]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201142048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50b10c5726c5de35359d8d8c1f8eac72496e26870cacbb4900371f647fe5ae09])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50b10c5726c5de35359d8d8c1f8eac72496e26870cacbb4900371f647fe5ae09
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:50b10c5726c5de35359d8d8c1f8eac72496e26870cacbb4900371f647fe5ae09].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 55s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1237

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1237/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Setup typedoc for doc generation.

[Robert Bradshaw] Quick pass adding some typescript docs and pointers.

[Robert Bradshaw] Add typescript doc gen to release process.

[Robert Bradshaw] Split README into user-facing and dev-facing portions.

[noreply] Merge pull request #25094: Externalizing the StreamWriter parameters for


------------------------------------------
[...truncated 859.31 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test3873/go-8-1675243139053017898/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201082048"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-083211"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-083211"
      }
    ]
  },
  "name": "go-testxlang_partition-233",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/02/01 09:19:08 Submitted job: 2023-02-01_01_19_07-6866617093116760975
2023/02/01 09:19:08 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-02-01_01_19_07-6866617093116760975?project=apache-beam-testing
2023/02/01 09:19:08 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-02-01_01_19_07-6866617093116760975
2023/02/01 09:19:08 Job state: JOB_STATE_PENDING ...
2023/02/01 09:19:38 Job still running ...
2023/02/01 09:20:08 Job still running ...
2023/02/01 09:20:38 Job still running ...
2023/02/01 09:21:08 Job still running ...
2023/02/01 09:21:38 Job still running ...
2023/02/01 09:22:08 Job still running ...
2023/02/01 09:22:38 Job still running ...
2023/02/01 09:23:08 Job still running ...
2023/02/01 09:23:38 Job still running ...
2023/02/01 09:24:08 Job still running ...
2023/02/01 09:24:38 Job still running ...
2023/02/01 09:25:08 Job still running ...
2023/02/01 09:25:38 Job still running ...
2023/02/01 09:26:09 Job still running ...
2023/02/01 09:26:39 Job still running ...
2023/02/01 09:27:09 Job still running ...
2023/02/01 09:27:39 Job still running ...
2023/02/01 09:28:09 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-02-01_01_19_07-6866617093116760975 failed
--- FAIL: TestXLang_Partition (580.40s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3353.310s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675240370333835100
--- FAIL: TestBigQueryIO_BasicWriteRead (5.65s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36723 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@SgpITAMcoQ" is_bounded:BOUNDED windowing_strategy_id:"w0@SgpITAMcoQ"}} windowing_strategies:{key:"w0@SgpITAMcoQ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@SgpITAMcoQ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@SgpITAMcoQ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@SgpITAMcoQ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675240370333835100\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"SgpITAMcoQ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36723 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@SgpITAMcoQ" is_bounded:BOUNDED windowing_strategy_id:"w0@SgpITAMcoQ"}} windowing_strategies:{key:"w0@SgpITAMcoQ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@SgpITAMcoQ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@SgpITAMcoQ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@SgpITAMcoQ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675240370333835100\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"SgpITAMcoQ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00013ca80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00013ca80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000504b20?, 0xc000517630?}, {0x110f943, 0x39}, {0xc00001e000?, 0xa969c0?, 0x1?}, {0xc000043d50, 0xf}, 0xc000571d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000504ac0?, 0xc000517630?}, {0xc00050a3c0, 0x52}, {0x1?}, {0xc000571ea8, 0x2, 0x7f29f8663998?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000043d50, 0xf}, {0xc00050a3c0, 0x52}, {0xe96fa0, 0xc000575070})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00048d380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00048d380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	8.686s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7b6e40300e509e49e8b1a9629ffdbac4cbb412bc3794f25837425b1249d84ed1
  Associated tags:
 - 20230201-083211
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-083211
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-083211].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:7b6e40300e509e49e8b1a9629ffdbac4cbb412bc3794f25837425b1249d84ed1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fa2f279825f5d5927b29b67e16c4ad7742f286745c56549e4bc46bca82eabeb1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fa2f279825f5d5927b29b67e16c4ad7742f286745c56549e4bc46bca82eabeb1])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fa2f279825f5d5927b29b67e16c4ad7742f286745c56549e4bc46bca82eabeb1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fa2f279825f5d5927b29b67e16c4ad7742f286745c56549e4bc46bca82eabeb1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201082048]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:17f0293e54601e9514a795d55253bb7cf5e7775dab4a0f9f0a5b6f421afe0bac]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201082048] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:17f0293e54601e9514a795d55253bb7cf5e7775dab4a0f9f0a5b6f421afe0bac])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:17f0293e54601e9514a795d55253bb7cf5e7775dab4a0f9f0a5b6f421afe0bac
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:17f0293e54601e9514a795d55253bb7cf5e7775dab4a0f9f0a5b6f421afe0bac].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 16s
216 actionable tasks: 148 executed, 56 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1236

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1236/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Deterministic ordering of gbk outputs for testing.

[Robert Bradshaw] Increase timeouts for cross-langauge tests.

[noreply] Ignore flags for beam_sql magic (#25210)

[noreply] Stop publishing empty test-only artifacts (#25191)

[noreply] Fix Debezium expansion service fail to start (#25243)


------------------------------------------
[...truncated 1016.73 KB...]
2023/02/01 03:39:58 Job still running ...
2023/02/01 03:40:28 Job still running ...
2023/02/01 03:40:58 Job still running ...
2023/02/01 03:41:28 Job still running ...
2023/02/01 03:41:58 Job still running ...
2023/02/01 03:42:28 Job still running ...
2023/02/01 03:42:58 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-31_19_33_57-9847306170384906736 failed
--- FAIL: TestXLang_Partition (580.77s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3451.215s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675219566090901672
--- FAIL: TestBigQueryIO_BasicWriteRead (6.47s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41799 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KRteLGZmFZ" is_bounded:BOUNDED windowing_strategy_id:"w0@KRteLGZmFZ"}} windowing_strategies:{key:"w0@KRteLGZmFZ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KRteLGZmFZ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KRteLGZmFZ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KRteLGZmFZ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675219566090901672\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KRteLGZmFZ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41799 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KRteLGZmFZ" is_bounded:BOUNDED windowing_strategy_id:"w0@KRteLGZmFZ"}} windowing_strategies:{key:"w0@KRteLGZmFZ" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KRteLGZmFZ" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KRteLGZmFZ" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KRteLGZmFZ" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675219566090901672\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KRteLGZmFZ"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0001135c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0001135c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00048eae0?, 0xc0000b8280?}, {0x110f943, 0x39}, {0xc0004f60c0?, 0xa969c0?, 0x1?}, {0xc0003f6d00, 0xf}, 0xc00002fd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00048ea80?, 0xc0000b8280?}, {0xc0005463c0, 0x52}, {0x1?}, {0xc00002fea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6d00, 0xf}, {0xc0005463c0, 0x52}, {0xe96fa0, 0xc0004a6a28})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004949c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004949c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.497s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-024512
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-024512
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4ca73cd1d00ffc75282ef18789cd6a21304e37819d62bddd937fd3a16026c620
Deleted: sha256:88ffbe822a94b473b741f2854de5f2d2a0a337a1f4f9f308bbd6c121e3c0feea
Deleted: sha256:d339d5237f10c84984bd90f4083c2fc7f6149fd46c614013ad046c8d8a42207c
Deleted: sha256:01a1089ff1807130b2cad5b52fb14d15566d79d9e5adbded7b7d39c8a6f98513
Deleted: sha256:0f52db7740fc2850799575d3805839aba081387b7ef0d4f293c97ef710d54b2a
Deleted: sha256:fa8b17679101b35c53808b943065a7d5993a858bbbfb30e477470c4615065e7a
Deleted: sha256:1f4e2007b7ab7c6e9b2f42678b52c890b7adef1d4c9db11098973eb4785d7aeb
Deleted: sha256:85ce10b4ec2e280a2d22c329f89f76c76e6c29d570ff64571f302f8f1409157a
Deleted: sha256:a4d7746c77a4ca7041e3271e96b1a70526e4d484bce1681ce34cc14a95814644
Deleted: sha256:eacc32a107efa67e97be1c3b3a5d734695d98d0ce55ecc41606fb800e97e30a0
Deleted: sha256:f07f602d321d26309be60ed63f25d3ccea6657e0540f4aa8195da5d50319f128
Deleted: sha256:cf8c765d6cadbf493bb0788053fd291db0e2728b0586c8b34f381ce167b00e78
Deleted: sha256:36a9e0da10857a2b05b88025f161326b4cd52ff00360a0b2e3644373a9179513
Deleted: sha256:29e3851cf779c6da1fae2b6c841edc19ffa7e5a8c36516ad2adf08d491ec6ccf
Deleted: sha256:7999c4797ba9d47db6cb30c6fa414ce2a449b16f61fe05928dbf7a0e66f5aa8c
Deleted: sha256:234f0a26093a529f71c3342706ee89a695fbe169b10f211e1e2753e0088b6783
Deleted: sha256:e4bbdd950dd86efcc4730e722fc2fbcc29a697d7424b23e45ccbd0486ebeb525
Deleted: sha256:44686bf4425256dfd8e7d5afa8e6dadeccc20bc83f2aeb954f45982cd6bb9a65
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-024512
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4ca73cd1d00ffc75282ef18789cd6a21304e37819d62bddd937fd3a16026c620
  Associated tags:
 - 20230201-024512
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-024512
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230201-024512].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:4ca73cd1d00ffc75282ef18789cd6a21304e37819d62bddd937fd3a16026c620].
$ rm -rf /tmp/tmp.disVzxhmZ8
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201022903
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201022903]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230201022903] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9cfe5f811c0681d12beffbd363e0b3634fd35bb7c3ac64f8914a93c231fe928b].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201022903
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9
Deleted: sha256:4c724830bbb6266985bedf4ccab85fd606bc00c224dd46320d5c39bb02b40bf3
Deleted: sha256:e0c7cb8177473690b85796e61a2c87d58cfa57512ad06c070f834ac8c5cafe34
Deleted: sha256:705c5ce14ee56ccd2e125376ff11a3ee4d14f2e5261f83607e64f2832ebb5b16
Deleted: sha256:cec43fb746ce5cfcbb3981cae282f90514433a33377e6439611676c7478db6f6
Deleted: sha256:b929470c55392beb64ca1358fac2a05047d5f6dbe5be0d494d76565effd8ca1a
Deleted: sha256:0b87578e96e731ebef28d786a63dc293d01b53b79e2be799797f62fc6d0f7e55
Deleted: sha256:fe28e862cc62b6d97b556255f8292eaa531d74160c0bf72dcd2a9a150744942e
Deleted: sha256:5304cc9e8703af39cc7bc41ffe5fa816498ec50422c9474b2345f0dac6cf136e
Deleted: sha256:29038ba25e882626fc1cb3edcfe4fa5aa45d0f8128b70fc42a2e18d6315cbd92
Deleted: sha256:cdfadf5d6811b494684a9bf009934a2e7786f492f5fa3ca92ac56b77c637a313
Deleted: sha256:5ae04ce8b490e1d98577c611ee7072bf6bca4a1d5d28944115be5b66964dc67f
Deleted: sha256:f3934b57115eb258ce7b08dbad6077400ccde430748874058b275d263fb8c0c9
Deleted: sha256:2aaa6d3683bd84fa7985fe69b5f0cf59f097417a6cdba7f7bb49fce31ace0113
Deleted: sha256:c233d735a2006648fbec8de942cc4840b96beb6cc88b3a835f16f7f22a3c73fc
Deleted: sha256:a45a2e01a1eb3163de468636a9d84a657ac27d0fd65fd17bdfc5649a48ed7c25
Deleted: sha256:1daaa19298837bba5cf61fe7109b191014470eebde6e65ece59ee24d2492821d
Deleted: sha256:12fcb9e73b67cfe05f12eb7e74a90449c5c8cc56ee95d1814935b87295ce72ef
Deleted: sha256:31c0da8e0e1695c34c02a8f8c14f4d02f796fa32a961228317ce7babacd8f4ac
Deleted: sha256:f3d52066faf09ad4fa841fd9598dfaaadc53c49d27d7d60f79ef69d1f2d0f459
Deleted: sha256:fedfcd61ec19f3f52a73f0b85424725f816aa6f3b34e0933214da177e32977eb
Deleted: sha256:69ae1145e94de882e33cd2d1091b845eafdc33ba246cc764545f7ad694c7ee14
Deleted: sha256:0be5d445013560e70ad7db6a5cf0845135e87105adbfc642ececaf420c5dad06
Deleted: sha256:7f6668d64e9dabf132dd8cfff5a89c0e16705cc32b64d218a40215c5d281583b
Deleted: sha256:a5cde990c3b19201b98f37857310001bd5452b65ea48caf4ec426dba53877f45
Deleted: sha256:81678123383a64c07a2b712d2d7dcb8a374b098f6d3e8b31ab53880fe422fa73
Deleted: sha256:3c13933f1e356fc9b04ae632f4a2b42a16d55f9df04a40816d7eece75132dde5
Deleted: sha256:7bc872b53eb7e29697c91f923428e9aad49ca785b08184e5ffc63c6001d22775
Deleted: sha256:e06ce9cf6d9cc5a30ca29272032fbdfbdbef2f448b0269398b5c96d89debb5cc
Deleted: sha256:bce95b367687e1bf7d4ccb0b07b25e88f948a29fdc8a24b50bbb40e2f823b35e
Deleted: sha256:13868b58cae68149cc89dd969be2346db4060a9a1298f2e6560f0cdc2e5f7f0c
Deleted: sha256:155e53a7886339988a1b3a0e479f74bbeebdf95dcb31c9ca91ca75610a999b3c
Deleted: sha256:f19d09899be8834081483883e291300e6c6324648de3adeb665ebdd8605f4f27
Deleted: sha256:6e6a97ec3b4cc8d552469555b1530bf1e48c73713c1ba50f6c5f8efdfc4f25f1
Deleted: sha256:56a640dd204f3117cbd60eaa1ec4d02287b911873111c78e420515ecf2fb6c6e
Deleted: sha256:7a0a73080e5446444c7841d40d2a88f51dd57030c354bb84cef653e66c6e2fc3
Deleted: sha256:63a10e51e05b99ef72adedbe28c0c2e92a254b82f22fb62d7368c62725f2d5bb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201022903]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230201022903] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:194258a182c3339859fb47678da35852bce4ec18bff05f54b1dad4b204c60ac9].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1621590.
Stopping expansion service pid: 1621591.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 14m 51s
216 actionable tasks: 149 executed, 55 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1235

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1235/display/redirect?page=changes>

Changes:

[noreply] Attempt fix GCPIO_Direct tests timeout (#25209)

[noreply] Fix pulling licenses (#25234)


------------------------------------------
[...truncated 1.00 MB...]
2023/01/31 21:28:36 Job still running ...
2023/01/31 21:29:06 Job still running ...
2023/01/31 21:29:37 Job still running ...
2023/01/31 21:30:07 Job still running ...
2023/01/31 21:30:37 Job still running ...
2023/01/31 21:31:07 Job still running ...
2023/01/31 21:31:37 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-31_13_22_04-14847554196326793633 failed
--- FAIL: TestXLang_Partition (610.66s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3361.052s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675197377410055291
--- FAIL: TestBigQueryIO_BasicWriteRead (5.94s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33995 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dJDPrCWbtC" is_bounded:BOUNDED windowing_strategy_id:"w0@dJDPrCWbtC"}} windowing_strategies:{key:"w0@dJDPrCWbtC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dJDPrCWbtC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dJDPrCWbtC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dJDPrCWbtC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675197377410055291\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dJDPrCWbtC"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:33995 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@dJDPrCWbtC" is_bounded:BOUNDED windowing_strategy_id:"w0@dJDPrCWbtC"}} windowing_strategies:{key:"w0@dJDPrCWbtC" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@dJDPrCWbtC" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@dJDPrCWbtC" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@dJDPrCWbtC" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675197377410055291\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"dJDPrCWbtC"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 9 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000658f80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000658f80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6b80?, 0xc0007435e0?}, {0x110f943, 0x39}, {0xc0000f0240?, 0xa969c0?, 0x1?}, {0xc000378000, 0xf}, 0xc000513d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6b20?, 0xc0007435e0?}, {0xc00004c8a0, 0x52}, {0x1?}, {0xc000513ea8, 0x2, 0x7f55184786c8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000378000, 0xf}, {0xc00004c8a0, 0x52}, {0xe96fa0, 0xc000379780})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0003dc9c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0003dc9c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	9.053s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.099s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.048s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.073s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-203521
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-203521
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a5150f1e5e34b2a52c09d86edae8f3af1536f8d93983f8705f8921321c72beb1
Deleted: sha256:cd1ecaeda8562e6bf0b61fb000f443451a8271bbf667034f1cf7ab6747da9f3d
Deleted: sha256:d3d0ce74c41b4129fa2701a6df5e347db5f91870558290652e3176d278f8eda6
Deleted: sha256:9d6adb71101799aa99f006d840474673bf9558eb6fa12de134e829f4a73d26b8
Deleted: sha256:e2ef2a1e6da5c8ff484b6f9b4b5f2964bf3f1458eb8697f90c4ce3d3bdd73e75
Deleted: sha256:9f4521a47431ac1051fbf6516dc019abaab97f5e1fb81bfce97312e2fc2fc999
Deleted: sha256:7af62f12c1e976ecadc95c7e6a39095e5e0774469430bf4303d0886edc45774f
Deleted: sha256:b7c211f2a3f3648fc6ef27849afa973b6febe9c2029fb44f061f6af875354605
Deleted: sha256:409c0d0ea606cc4377c869377103461c8d11df7b7cd451becab38f82f85e3395
Deleted: sha256:47714923baff10d7bd19464fcb87c63726d7cc4685fb0d9a0cbf68c22a3e4128
Deleted: sha256:15fe46632834fcc934b6c0be49b17a7f95aa60ee0379fa2a5610aef252217fed
Deleted: sha256:a00b7373d673be7c69e51ce9f92986e2365ef340b01859694a29a5352b6883f2
Deleted: sha256:e7627565c1dc2e8be61200c60c9dd1ba84a31d5a9a6ddc8706a100165567f530
Deleted: sha256:8892705d02f01b422f5dea150086cd3874388a115b5e1d8ad6cda7a77b1f38b8
Deleted: sha256:4e9c1e83e7a11401cf275c64757767d7b22d0ad51a84c3584ad74345d1d0a71e
Deleted: sha256:a910428aa353763056468845749262b65d86c880347c52364dc7c3d39e84bfad
Deleted: sha256:24895ec1605a5b37291352b01dce8d6fdfbca531cbdf98abcce75f4bd8052a7b
Deleted: sha256:ae92f63d65a1f2c2b7a114c6dd63ab0d35f148712a012b9dc8d7fb489f466b3f
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-203521
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a5150f1e5e34b2a52c09d86edae8f3af1536f8d93983f8705f8921321c72beb1
  Associated tags:
 - 20230131-203521
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-203521
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-203521].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a5150f1e5e34b2a52c09d86edae8f3af1536f8d93983f8705f8921321c72beb1].
$ rm -rf /tmp/tmp.cR3y1gsQCT
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131202046
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131202046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131202046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:ddeb201cf97b1f11483fb81fef4a1f0e9a4a09d8f1f5ea30684499a95263a2bb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131202046
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20
Deleted: sha256:fece0c920073eddec478f16a6afe6f60ec4676043e91c11789b306b68c3efb6f
Deleted: sha256:a247339fc68cf617a522932142f6f94998bb9360b489cddcf26243ff9dbdc589
Deleted: sha256:79ba33b6b9ac42c6efd9afd7441af1dfd08e0f156679b26c038b849e9b46d67f
Deleted: sha256:7e95fdec3b61c21052ac782b33beee794cb9bbb8b91eaa15f1ff1dc0754a1fb8
Deleted: sha256:47ffaa5bc3ead274f2d3081b027368b70f7c56a6d9839a9d8792fc318d2b5af0
Deleted: sha256:e33cdf6b4f7d2c316a02e4f6ba9cf93a4513333b506218ed3a07a32576939e85
Deleted: sha256:c9cf68a831e2f11652122c2bd9515e7998678d6872262e884349921f49527295
Deleted: sha256:cd58de2474d8e817954e5642d8b8cbab72e792639903b968df5bfd19554887c6
Deleted: sha256:f5a925ea4eb1de1f78a4ea2f53ffc00833d5dd9ad4a92b127362be75170d86a8
Deleted: sha256:043bbef4527f611bcd07dc8c7c9f3a301453deda69329775aab173c01f971932
Deleted: sha256:2f1f7b40641686ff72e9382ffdd0f84e47319d954564d665ce2fb389ea38699f
Deleted: sha256:a299f62243e4e30c04d88798ea4cb1c5c1e836b4871e7de37b300623e66bedb1
Deleted: sha256:ab1051eef3d7b77446f87a2a391bbf80d39c9300fad1f482bb0ee19ca3f2b992
Deleted: sha256:973753033e4cf8962c061c59dd1729c595a210a7fb33566ec6628c09a928aa2d
Deleted: sha256:b32f837b0e98e7fe9d447b49710c8e2744d74b6dac6ff958478307880cd55a4d
Deleted: sha256:ba2b127060dd83a3eae6ff56e6e7390c2210ea102221afc0282bd18b42490971
Deleted: sha256:f0ce7f3165bbf0eb315c22f8b9ec38b5228b46a945b3c5711fff3005a425dd70
Deleted: sha256:7333502bd374dcdbf61eb73cf9a9ef9974ac6260c6f34093c511df6ef8c74fb3
Deleted: sha256:4143278cc628737e8363a8164cca2eef280de05b30eb527cb20d5383a55d5532
Deleted: sha256:737203d106959acd66d115a3c208cfa3d586832e2fb0e392b6443bab81e52ee4
Deleted: sha256:7d4d4c728850c9f0ecdfc39a5ceb3ad8dce1dd60996a885f958da803a0f25c79
Deleted: sha256:85ac5416e7fbbe7df75e90a86d1b5e54c1174524f5f2af15f43f68d6a617c7c5
Deleted: sha256:489630f674f153e37f4c599d20991daa8e656071dcd4b8f48bbd6203d358b4cb
Deleted: sha256:d5554e461f8381b223d2fb51bc6ed6c1a765ab01d6b6740fe98ba868dc1a94a8
Deleted: sha256:254a8c36945f5e28a2908c20aca2492d1ca99e7e99a87a1610d0c2cbd01e4557
Deleted: sha256:1acd9bfbc8af7974de7eccb7a30f6773c155772ac0617f11af5be2c969f94845
Deleted: sha256:c0fa0aa098d07955cdba9a65e3f84e2c657f9d086458d5796ac42cc82b227523
Deleted: sha256:f4047c5e49574d5bd0e9d9d343fc9dfbcf13f093f17399b5f74ba06c2b209ec7
Deleted: sha256:334267eae6064e55b7095ac211efe787b9718aa11e5051c6c6a5d6c8923585ea
Deleted: sha256:ad0087d8fb27d60b14bd89ca7477cc363f230cf608340dffe382b6f8a6a34a48
Deleted: sha256:44452659df6e7dee25ab79e8e631972fbc4fc6da7528fea014ae6e327137046b
Deleted: sha256:bd7e33a59c17cd476da07b7376043f9530eab1100183cab406c452cb6b9f575d
Deleted: sha256:da1111ace84e221cbf7da92c7b91590dafbdf0c03c51ba259407ea0f1a407092
Deleted: sha256:74ba747e8b66211ad52ff78ebe390cda21f8ac5d4de5749a421a93edb048fd3c
Deleted: sha256:26bf6df2108589c6d0b5450a22668f59740f17b98b473c8b12dc7bd3b0dc5f29
Deleted: sha256:8e661d1371b3a783d9e8489fa3ebb6bc08c89c68bae163877148954b7f8effec
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131202046]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131202046] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:7c9e2d4638552860c543874f43c26f2969ded1d68afb5a587a33d5729e558c20].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 4046940.
Stopping expansion service pid: 4046941.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 11m 49s
216 actionable tasks: 151 executed, 53 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1234

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1234/display/redirect>

Changes:


------------------------------------------
[...truncated 605.19 KB...]
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.0.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container d0325cc7cd61
 ---> 1d3d83cb280d
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 1b23da6e9ad1
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> 306a6b4c21e7
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 4f05853a76d4
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> d87adde909bd
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in d2f60a15ee92
Removing intermediate container d2f60a15ee92
 ---> 8da0d958c4cc
Step 22/32 : FROM beam as third_party_licenses
 ---> 8da0d958c4cc
Step 23/32 : ARG pull_licenses
 ---> Running in 0e708cc8baf5
Removing intermediate container 0e708cc8baf5
 ---> eacee5b1135a
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> a8d43b8ad029
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> 8e3c6afcce26
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 2bca5e62f42a
Removing intermediate container 2bca5e62f42a
 ---> 8e906d35f740
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> e76670becabc
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in d5663ec67b20
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=a77512c6448248ac5c41f583cc1a4c7edc84a325d12e8af75f48639164ce407a
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Skip pulling license for  bs4
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 176, in <module>
    pull_from_url(dep['Name'].lower(), dep_config['pip_dependencies'])):
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 293, in wrapped_f
    return self.call(f, *args, **kw)
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 359, in call
    do = self.iter(retry_state=retry_state)
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 332, in iter
    raise retry_exc.reraise()
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 168, in reraise
    raise self.last_attempt.result()
  File "/usr/local/lib/python3.8/concurrent/futures/_base.py", line 437, in result
    return self.__get_result()
  File "/usr/local/lib/python3.8/concurrent/futures/_base.py", line 389, in __get_result
    raise self._exception
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 362, in call
    result = fn(*args, **kwargs)
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
The command '/bin/sh -c if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi' returned a non-zero code: 1

> Task :sdks:python:container:py38:docker FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:container:py38:docker'.
> Process 'command 'docker'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 10m 22s
210 actionable tasks: 137 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1233

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1233/display/redirect?page=changes>

Changes:

[noreply] Standardizing naming and URN for Pubsub Read Schema Transform (#25170)


------------------------------------------
[...truncated 599.83 KB...]
pycparser==2.21
pydot==1.4.2
PyHamcrest==1.10.1
pymongo==3.13.0
PyMySQL==1.0.2
pyparsing==3.0.9
pytest==7.2.1
pytest-forked==1.4.0
pytest-timeout==2.1.0
pytest-xdist==2.5.0
python-dateutil==2.8.2
python-snappy==0.6.1
pytz==2022.7.1
PyYAML==6.0
regex==2022.10.31
requests==2.28.2
requests-mock==1.10.0
requests-oauthlib==1.3.1
rsa==4.9
scikit-learn==1.2.1
scipy==1.10.0
setuptools==67.0.0
six==1.16.0
sortedcontainers==2.4.0
soupsieve==2.3.2.post1
SQLAlchemy==1.4.46
sqlparse==0.4.3
tenacity==5.1.5
tensorboard==2.11.2
tensorboard-data-server==0.6.1
tensorboard-plugin-wit==1.8.1
tensorflow==2.11.0
tensorflow-estimator==2.11.0
tensorflow-io-gcs-filesystem==0.30.0
termcolor==2.2.0
testcontainers==3.7.1
threadpoolctl==3.1.0
tomli==2.0.1
tqdm==4.64.1
typing_extensions==4.4.0
uritemplate==4.1.1
urllib3==1.26.14
websocket-client==1.4.2
Werkzeug==2.2.2
wheel==0.38.4
wrapt==1.14.1
zipp==3.11.0
zstandard==0.19.0
Removing intermediate container e6ef7f9e4efd
 ---> 303b38ff45e9
Step 17/32 : COPY target/LICENSE /opt/apache/beam/
 ---> 8b9652b6fde0
Step 18/32 : COPY target/LICENSE.python /opt/apache/beam/
 ---> b2ef67f91ce5
Step 19/32 : COPY target/NOTICE /opt/apache/beam/
 ---> 211989f962bf
Step 20/32 : COPY target/launcher/linux_amd64/boot /opt/apache/beam/
 ---> 26396414f319
Step 21/32 : ENTRYPOINT ["/opt/apache/beam/boot"]
 ---> Running in 4ab5f3a54367
Removing intermediate container 4ab5f3a54367
 ---> 5e608903b0af
Step 22/32 : FROM beam as third_party_licenses
 ---> 5e608903b0af
Step 23/32 : ARG pull_licenses
 ---> Running in e24bc4273633
Removing intermediate container e24bc4273633
 ---> b4b8f15e4a1c
Step 24/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> b55ffed27a80
Step 25/32 : COPY target/LICENSE target/go-licenses/* /opt/apache/beam/third_party_licenses/golang/
 ---> ac2ca199be24
Step 26/32 : RUN rm /opt/apache/beam/third_party_licenses/golang/LICENSE
 ---> Running in 2c7de5f579a5
Removing intermediate container 2c7de5f579a5
 ---> dd6de7d01dd1
Step 27/32 : COPY target/license_scripts /tmp/license_scripts/
 ---> 62d90287bccd
Step 28/32 : RUN if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi
 ---> Running in 7c36c1f80234
Collecting pip-licenses<4.0.0
  Downloading pip_licenses-3.5.5-py3-none-any.whl (17 kB)
Requirement already satisfied: pyyaml in /usr/local/lib/python3.8/site-packages (6.0)
Requirement already satisfied: tenacity in /usr/local/lib/python3.8/site-packages (5.1.5)
Collecting PTable
  Downloading PTable-0.9.2.tar.gz (31 kB)
  Preparing metadata (setup.py): started
  Preparing metadata (setup.py): finished with status 'done'
Requirement already satisfied: six>=1.9.0 in /usr/local/lib/python3.8/site-packages (from tenacity) (1.16.0)
Building wheels for collected packages: PTable
  Building wheel for PTable (setup.py): started
  Building wheel for PTable (setup.py): finished with status 'done'
  Created wheel for PTable: filename=PTable-0.9.2-py3-none-any.whl size=22908 sha256=a4046a62c457c9508f789e7e2589c1c7a76aee916b4ddc44b4b51b4898f7fe68
  Stored in directory: /root/.cache/pip/wheels/1b/3a/02/8d8da2bca2223dda2f827949c88b2d82dc85dccbc2bb6265e5
Successfully built PTable
Installing collected packages: PTable, pip-licenses
Successfully installed PTable-0.9.2 pip-licenses-3.5.5
WARNING: Running pip as the 'root' user can result in broken permissions and conflicting behaviour with the system package manager. It is recommended to use a virtual environment instead: https://pip.pypa.io/warnings/venv
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
ERROR:root:Error occurred when pull license for flatbuffers from {'license': 'https://raw.githubusercontent.com/google/flatbuffers/master/LICENSE.txt'}.
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
Skip pulling license for  bs4
Traceback (most recent call last):
  File "/tmp/license_scripts/pull_licenses_py.py", line 176, in <module>
    pull_from_url(dep['Name'].lower(), dep_config['pip_dependencies'])):
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 293, in wrapped_f
    return self.call(f, *args, **kw)
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 359, in call
    do = self.iter(retry_state=retry_state)
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 332, in iter
    raise retry_exc.reraise()
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 168, in reraise
    raise self.last_attempt.result()
  File "/usr/local/lib/python3.8/concurrent/futures/_base.py", line 437, in result
    return self.__get_result()
  File "/usr/local/lib/python3.8/concurrent/futures/_base.py", line 389, in __get_result
    raise self._exception
  File "/usr/local/lib/python3.8/site-packages/tenacity/__init__.py", line 362, in call
    result = fn(*args, **kwargs)
  File "/tmp/license_scripts/pull_licenses_py.py", line 97, in pull_from_url
    url_read = urlopen(Request(config['license'],
  File "/usr/local/lib/python3.8/urllib/request.py", line 222, in urlopen
    return opener.open(url, data, timeout)
  File "/usr/local/lib/python3.8/urllib/request.py", line 531, in open
    response = meth(req, response)
  File "/usr/local/lib/python3.8/urllib/request.py", line 640, in http_response
    response = self.parent.error(
  File "/usr/local/lib/python3.8/urllib/request.py", line 569, in error
    return self._call_chain(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 502, in _call_chain
    result = func(*args)
  File "/usr/local/lib/python3.8/urllib/request.py", line 649, in http_error_default
    raise HTTPError(req.full_url, code, msg, hdrs, fp)
urllib.error.HTTPError: HTTP Error 404: Not Found
The command '/bin/sh -c if [ "$pull_licenses" = "true" ] ; then       pip install 'pip-licenses<4.0.0' pyyaml tenacity &&       python /tmp/license_scripts/pull_licenses_py.py ;     fi' returned a non-zero code: 1

> Task :sdks:python:container:py38:docker FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':sdks:python:container:py38:docker'.
> Process 'command 'docker'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 10m 7s
210 actionable tasks: 139 executed, 59 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1232

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1232/display/redirect?page=changes>

Changes:

[noreply] Update Github issues link for Go SDK (#25161)

[noreply] Fix typo. (#21864)


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test1449/go-8-1675135144339984663/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131022049"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240"
      }
    ]
  },
  "name": "go-testxlang_partition-777",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/31 03:19:12 Submitted job: 2023-01-30_19_19_12-8308538963157476848
2023/01/31 03:19:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-30_19_19_12-8308538963157476848?project=apache-beam-testing
2023/01/31 03:19:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-30_19_19_12-8308538963157476848
2023/01/31 03:19:12 Job state: JOB_STATE_PENDING ...
2023/01/31 03:19:42 Job still running ...
2023/01/31 03:20:13 Job still running ...
2023/01/31 03:20:43 Job still running ...
2023/01/31 03:21:13 Job still running ...
2023/01/31 03:21:43 Job still running ...
2023/01/31 03:22:13 Job still running ...
2023/01/31 03:22:43 Job still running ...
2023/01/31 03:23:13 Job still running ...
2023/01/31 03:23:43 Job still running ...
2023/01/31 03:24:13 Job still running ...
2023/01/31 03:24:43 Job still running ...
2023/01/31 03:25:13 Job still running ...
2023/01/31 03:25:43 Job still running ...
2023/01/31 03:26:13 Job still running ...
2023/01/31 03:26:43 Job still running ...
2023/01/31 03:27:13 Job still running ...
2023/01/31 03:27:43 Job still running ...
2023/01/31 03:28:13 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-30_19_19_12-8308538963157476848 failed
--- FAIL: TestXLang_Partition (579.76s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3329.047s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675132398252501151
--- FAIL: TestBigQueryIO_BasicWriteRead (4.40s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45245 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KcVhVQaBxg" is_bounded:BOUNDED windowing_strategy_id:"w0@KcVhVQaBxg"}} windowing_strategies:{key:"w0@KcVhVQaBxg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KcVhVQaBxg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KcVhVQaBxg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KcVhVQaBxg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675132398252501151\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KcVhVQaBxg"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:45245 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KcVhVQaBxg" is_bounded:BOUNDED windowing_strategy_id:"w0@KcVhVQaBxg"}} windowing_strategies:{key:"w0@KcVhVQaBxg" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KcVhVQaBxg" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KcVhVQaBxg" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KcVhVQaBxg" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675132398252501151\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KcVhVQaBxg"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00067e480})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00067e480})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000169ba0?, 0xc000139a90?}, {0x110f943, 0x39}, {0xc000022000?, 0xa969c0?, 0x1?}, {0xc0003f2e80, 0xf}, 0xc0005f7d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169ae0?, 0xc000139a90?}, {0xc00004c540, 0x52}, {0x1?}, {0xc0005f7ea8, 0x2, 0x7f6d4ecf0b88?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f2e80, 0xf}, {0xc00004c540, 0x52}, {0xe96fa0, 0xc0005fe420})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000ca9c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000ca9c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.431s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.047s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:660ac76de02c08922914225eeec8e0e8f1d78484559bc59baa8c19f984e3e96a
Deleted: sha256:a74fb3d2c068768fb7dc875a639409ccac3d3edbdff9dfeaadd8e3b696386787
Deleted: sha256:16c9e47dbb426533dde27c9bdca2ef5d5b943a075776c5dd18306a9e1ffc2791
Deleted: sha256:3b5c617ec113afd9c401b99be97acf2088a51563484cef6abb9bd9c568179d81
Deleted: sha256:1e2baae777048488d468a4f9089f81cd447d257ceccd3ec0889c8aaf6df5120a
Deleted: sha256:e58a0208f5c4a09278a88afaf77bcaa917468929cd9ceb6ef0d201478e751c64
Deleted: sha256:cfe30cd5fbe0293a8d2fd7445c60d3e0c68a1aa99736bec793b65f6b9bd757ed
Deleted: sha256:d783259bb14303b89820455bdaa11becae8dc85872f5898827f3362447a270f2
Deleted: sha256:29b18d1fd78945870706393c7d36422d3d1da72a5fb919411ddd009ee1b14fa6
Deleted: sha256:83e8c1627574ff7950f627b47c19d1639a268832a0f22b72d6cc4ba3fb3c3530
Deleted: sha256:f6a3f173e5c24eecfb25014e915eedf7b0a86acd283e9af0c39ac579bfcbdb63
Deleted: sha256:8a704d0592a5ca984257d062629199cba0045b6a14532c904dead28d209af72a
Deleted: sha256:1834262ffc84e7f309a49e7d61c63af308bec436b585f458c6ef14b941ac92a9
Deleted: sha256:ba7ef70045be5409e64d903597d59420369c773598161643e1b00a61f285d2c8
Deleted: sha256:2df413d3681063e8f968047966d176cb6f16243d86667e1e355cba8c98f379b1
Deleted: sha256:850e2c29e239395ea86ea0b71fdb7bfa015679dcfaed805c09a41f30a678c363
Deleted: sha256:256d572e0df16f7130607b7b5ca528689bd3bf9e85f67eceb386a1ca26d2ed8e
Deleted: sha256:302d49553c4a466203fb3fc9be6e4aa9e71772995a850f9b75a58df10b5f8a9e
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:660ac76de02c08922914225eeec8e0e8f1d78484559bc59baa8c19f984e3e96a
  Associated tags:
 - 20230131-023240
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230131-023240].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:660ac76de02c08922914225eeec8e0e8f1d78484559bc59baa8c19f984e3e96a].
$ rm -rf /tmp/tmp.K8xJMII5SR
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131022049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230131022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:c3a261705590264fe45cc130836f9482e980e37c8aa1a0b37194480c10416cd8].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131022049
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131022049]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230131022049] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:63f62faabec388764eb3d9d03fea78af5f56c706cc4bc2b6a2a989d07e9882a0].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 3260897.
Stopping expansion service pid: 3260898.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 20s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1231

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1231/display/redirect?page=changes>

Changes:

[noreply] Fix Jdbc Write after window assigned (#25173)


------------------------------------------
[...truncated 1012.20 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test6522/go-8-1675113604823141330/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130202054"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-203244"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-203244"
      }
    ]
  },
  "name": "go-testxlang_partition-70",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/30 21:20:13 Submitted job: 2023-01-30_13_20_12-5639876910533258706
2023/01/30 21:20:13 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-30_13_20_12-5639876910533258706?project=apache-beam-testing
2023/01/30 21:20:13 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-30_13_20_12-5639876910533258706
2023/01/30 21:20:13 Job state: JOB_STATE_PENDING ...
2023/01/30 21:20:43 Job still running ...
2023/01/30 21:21:13 Job still running ...
2023/01/30 21:21:43 Job still running ...
2023/01/30 21:22:13 Job still running ...
2023/01/30 21:22:43 Job still running ...
2023/01/30 21:23:13 Job still running ...
2023/01/30 21:23:43 Job still running ...
2023/01/30 21:24:13 Job still running ...
2023/01/30 21:24:43 Job still running ...
2023/01/30 21:25:13 Job still running ...
2023/01/30 21:25:43 Job still running ...
2023/01/30 21:26:13 Job still running ...
2023/01/30 21:26:44 Job still running ...
2023/01/30 21:27:14 Job still running ...
2023/01/30 21:27:44 Job still running ...
2023/01/30 21:28:14 Job still running ...
2023/01/30 21:28:44 Job still running ...
2023/01/30 21:29:14 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-30_13_20_12-5639876910533258706 failed
--- FAIL: TestXLang_Partition (579.81s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3387.695s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675110800112651196
--- FAIL: TestBigQueryIO_BasicWriteRead (4.38s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41601 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zFBFfVKeGH" is_bounded:BOUNDED windowing_strategy_id:"w0@zFBFfVKeGH"}} windowing_strategies:{key:"w0@zFBFfVKeGH" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zFBFfVKeGH" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zFBFfVKeGH" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zFBFfVKeGH" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675110800112651196\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zFBFfVKeGH"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:41601 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@zFBFfVKeGH" is_bounded:BOUNDED windowing_strategy_id:"w0@zFBFfVKeGH"}} windowing_strategies:{key:"w0@zFBFfVKeGH" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@zFBFfVKeGH" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@zFBFfVKeGH" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@zFBFfVKeGH" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675110800112651196\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"zFBFfVKeGH"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 39 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00048cb40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00048cb40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a67a0?, 0xc0000ce0a0?}, {0x110f943, 0x39}, {0xc00015e180?, 0xa969c0?, 0x1?}, {0xc000492c70, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6740?, 0xc0000ce0a0?}, {0xc0004c0360, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000492c70, 0xf}, {0xc0004c0360, 0x52}, {0xe96fa0, 0xc0003f0238})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000c8820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000c8820, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.410s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.039s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.034s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f2aa06c746631384f5673549a09da19a64c7bf4d628cec572a7832b90212bee5
  Associated tags:
 - 20230130-203244
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-203244
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-203244].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:f2aa06c746631384f5673549a09da19a64c7bf4d628cec572a7832b90212bee5].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130202054]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a002fd04abd248112dc342b612bfe90c5480377c7850523091215781ec1ace0d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130202054] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a002fd04abd248112dc342b612bfe90c5480377c7850523091215781ec1ace0d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a002fd04abd248112dc342b612bfe90c5480377c7850523091215781ec1ace0d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:a002fd04abd248112dc342b612bfe90c5480377c7850523091215781ec1ace0d].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130202054]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:85b10164280f768ea864fa150dd8355e149135367a667a51e5ecbb97b495ab9d]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130202054] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:85b10164280f768ea864fa150dd8355e149135367a667a51e5ecbb97b495ab9d])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:85b10164280f768ea864fa150dd8355e149135367a667a51e5ecbb97b495ab9d
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:85b10164280f768ea864fa150dd8355e149135367a667a51e5ecbb97b495ab9d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 20s
216 actionable tasks: 152 executed, 52 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1230

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1230/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test8315/go-8-1675092009127511013/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130142055"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347"
      }
    ]
  },
  "name": "go-testxlang_partition-79",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/30 15:20:18 Submitted job: 2023-01-30_07_20_17-4717128324312450511
2023/01/30 15:20:18 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-30_07_20_17-4717128324312450511?project=apache-beam-testing
2023/01/30 15:20:18 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-30_07_20_17-4717128324312450511
2023/01/30 15:20:18 Job state: JOB_STATE_PENDING ...
2023/01/30 15:20:48 Job still running ...
2023/01/30 15:21:18 Job still running ...
2023/01/30 15:21:48 Job still running ...
2023/01/30 15:22:18 Job still running ...
2023/01/30 15:22:48 Job still running ...
2023/01/30 15:23:18 Job still running ...
2023/01/30 15:23:48 Job still running ...
2023/01/30 15:24:18 Job still running ...
2023/01/30 15:24:48 Job still running ...
2023/01/30 15:25:18 Job still running ...
2023/01/30 15:25:48 Job still running ...
2023/01/30 15:26:18 Job still running ...
2023/01/30 15:26:48 Job still running ...
2023/01/30 15:27:18 Job still running ...
2023/01/30 15:27:48 Job still running ...
2023/01/30 15:28:19 Job still running ...
2023/01/30 15:28:49 Job still running ...
2023/01/30 15:29:19 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-30_07_20_17-4717128324312450511 failed
--- FAIL: TestXLang_Partition (580.35s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3322.860s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675089269778571121
--- FAIL: TestBigQueryIO_BasicWriteRead (4.90s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44335 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@gprMOMrPJR" is_bounded:BOUNDED windowing_strategy_id:"w0@gprMOMrPJR"}} windowing_strategies:{key:"w0@gprMOMrPJR" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@gprMOMrPJR" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@gprMOMrPJR" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@gprMOMrPJR" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675089269778571121\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"gprMOMrPJR"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44335 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@gprMOMrPJR" is_bounded:BOUNDED windowing_strategy_id:"w0@gprMOMrPJR"}} windowing_strategies:{key:"w0@gprMOMrPJR" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@gprMOMrPJR" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@gprMOMrPJR" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@gprMOMrPJR" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675089269778571121\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"gprMOMrPJR"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0000b0b00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0000b0b00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00068e2c0?, 0xc0000ba050?}, {0x110f943, 0x39}, {0xc00015a180?, 0xa969c0?, 0x1?}, {0xc000680d40, 0xf}, 0xc0005f7d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00068e260?, 0xc0000ba050?}, {0xc00004c4e0, 0x52}, {0x1?}, {0xc0005f7ea8, 0x2, 0x7fc4878b2448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000680d40, 0xf}, {0xc00004c4e0, 0x52}, {0xe96fa0, 0xc0000421d0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004a5380)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004a5380, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.936s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.042s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.036s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.036s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eea9c86407481099da72e65befe2e3aa0bead45cbecbabe2410a250fdb5beaa4
Deleted: sha256:2911d42e7cd5a624524e97cb16165a862ed108317e2593eb64a902adb7b48035
Deleted: sha256:9d383d26fa06d222f9d8a93fb5dbdaa902669d605fb3736ac1fa743034066e86
Deleted: sha256:2b70935577db1334aeba6fd7bc3700b2174a6e0537a26654cb77ff419747dd40
Deleted: sha256:08fc31a2b6cb0d567912e6df9b2e67563e2ece6219dc250188ddd3aacc8a1930
Deleted: sha256:f5d5807e272ae2ea5b8089f1b12f9a8e1be776f0ab66f33888d7bd06c61b6b8c
Deleted: sha256:4d01c85a433ab347e8dc74580fb1b0e9f149340078a6e9ffe4ad9747461e2374
Deleted: sha256:c3a36e5e0135cba8104a1b4e454d6544be9205a9f8a2fc2d1bfd8e430d55cd3a
Deleted: sha256:97d7c0f30249e96023d36d6a713032d16b303122153e43bb5b88fe31355bf02a
Deleted: sha256:29ff02ee7246b701b2d35e11bf640c7b3b86a271348b162c7ccc4b439e468bf2
Deleted: sha256:e392f3701b820200f07606aa9281b6b63ad8cebdd058bef9184e7e23e0ecc655
Deleted: sha256:39392ec5a70fb4171995bc7c37471025130333403206fccbdcd5c58f9c4a795c
Deleted: sha256:30c4a31ff1cf4f0a08704325deaccab30046ef248a10fb589f0701f3bba6ec4f
Deleted: sha256:58193a2683d4b4d8316941c7366d35749b5631b189b10fafeab5feb453aafe1d
Deleted: sha256:e895d200f104d52e19246fd85116cccb623360bed7e5275009c426224957e14e
Deleted: sha256:f067a5b4235d9046c1f809078c44810e55da6cb2823e8d824c8c21bc9457f984
Deleted: sha256:5c859b96b232d547b769fa0c890f0929af71c3ed2ecd6afa556b8c265a5d97c8
Deleted: sha256:3d2dd9d37e06923cf75beaac4dfb260f676246ef8528d03548204c37b8591422
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eea9c86407481099da72e65befe2e3aa0bead45cbecbabe2410a250fdb5beaa4
  Associated tags:
 - 20230130-143347
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-143347].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:eea9c86407481099da72e65befe2e3aa0bead45cbecbabe2410a250fdb5beaa4].
$ rm -rf /tmp/tmp.GEc2cSVmQu
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130142055
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130142055]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130142055] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:46521d082f84d6a3c622aa853fc4c6bd0ea196b0660b993ff9cd709fa3d9bed0].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130142055
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130142055]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130142055] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:68ab3b7d353e73b6aea98df03662fb62d2ec5c7c0348f9bd1fc5636c98f3873a].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1918097.
Stopping expansion service pid: 1918099.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 27s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1229

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1229/display/redirect>

Changes:


------------------------------------------
[...truncated 1007.93 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test5826/go-8-1675070312502350175/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130082045"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-083218"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-083218"
      }
    ]
  },
  "name": "go-testxlang_partition-337",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/30 09:18:41 Submitted job: 2023-01-30_01_18_40-2370316902255502684
2023/01/30 09:18:41 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-30_01_18_40-2370316902255502684?project=apache-beam-testing
2023/01/30 09:18:41 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-30_01_18_40-2370316902255502684
2023/01/30 09:18:41 Job state: JOB_STATE_PENDING ...
2023/01/30 09:19:11 Job still running ...
2023/01/30 09:19:41 Job still running ...
2023/01/30 09:20:11 Job still running ...
2023/01/30 09:20:41 Job still running ...
2023/01/30 09:21:12 Job still running ...
2023/01/30 09:21:42 Job still running ...
2023/01/30 09:22:12 Job still running ...
2023/01/30 09:22:42 Job still running ...
2023/01/30 09:23:12 Job still running ...
2023/01/30 09:23:42 Job still running ...
2023/01/30 09:24:12 Job still running ...
2023/01/30 09:24:42 Job still running ...
2023/01/30 09:25:12 Job still running ...
2023/01/30 09:25:42 Job still running ...
2023/01/30 09:26:12 Job still running ...
2023/01/30 09:26:42 Job still running ...
2023/01/30 09:27:12 Job still running ...
2023/01/30 09:27:42 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-30_01_18_40-2370316902255502684 failed
--- FAIL: TestXLang_Partition (580.34s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3321.391s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675067574534646654
--- FAIL: TestBigQueryIO_BasicWriteRead (4.20s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KzEtlMBCST" is_bounded:BOUNDED windowing_strategy_id:"w0@KzEtlMBCST"}} windowing_strategies:{key:"w0@KzEtlMBCST" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KzEtlMBCST" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KzEtlMBCST" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KzEtlMBCST" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675067574534646654\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KzEtlMBCST"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:34837 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@KzEtlMBCST" is_bounded:BOUNDED windowing_strategy_id:"w0@KzEtlMBCST"}} windowing_strategies:{key:"w0@KzEtlMBCST" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@KzEtlMBCST" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@KzEtlMBCST" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@KzEtlMBCST" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675067574534646654\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"KzEtlMBCST"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0004546c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0004546c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0001699e0?, 0xc0000c1680?}, {0x110f943, 0x39}, {0xc00015e0c0?, 0xa969c0?, 0x1?}, {0xc0003f16d0, 0xf}, 0xc000159d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000169980?, 0xc0000c1680?}, {0xc00001c360, 0x52}, {0x1?}, {0xc000159ea8, 0x2, 0x7f30a56cd328?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f16d0, 0xf}, {0xc00001c360, 0x52}, {0xe96fa0, 0xc0000fa9e0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0004936c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0004936c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.228s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.043s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bb794cfe8f03f022e630013faa5c71e706f7b28d8c7e22f5c15f34eeba63f4f1
  Associated tags:
 - 20230130-083218
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-083218
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-083218].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:bb794cfe8f03f022e630013faa5c71e706f7b28d8c7e22f5c15f34eeba63f4f1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b0d5926ae2fe8d94005cfbf1a97a00f715174894169794883fed4320dff586a9]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b0d5926ae2fe8d94005cfbf1a97a00f715174894169794883fed4320dff586a9])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b0d5926ae2fe8d94005cfbf1a97a00f715174894169794883fed4320dff586a9
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:b0d5926ae2fe8d94005cfbf1a97a00f715174894169794883fed4320dff586a9].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130082045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6b92108a2da98494ca465fc89c0641f804ec10534447fe9b4bbbfb15b3dc44e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130082045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6b92108a2da98494ca465fc89c0641f804ec10534447fe9b4bbbfb15b3dc44e])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6b92108a2da98494ca465fc89c0641f804ec10534447fe9b4bbbfb15b3dc44e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:c6b92108a2da98494ca465fc89c0641f804ec10534447fe9b4bbbfb15b3dc44e].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 52s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1228

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1228/display/redirect>

Changes:


------------------------------------------
[...truncated 1.01 MB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test16236/go-8-1675048643809279981/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130022045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209"
      }
    ]
  },
  "name": "go-testxlang_partition-907",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/30 03:17:33 Submitted job: 2023-01-29_19_17_32-17273083713657177367
2023/01/30 03:17:33 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-29_19_17_32-17273083713657177367?project=apache-beam-testing
2023/01/30 03:17:33 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-29_19_17_32-17273083713657177367
2023/01/30 03:17:33 Job state: JOB_STATE_PENDING ...
2023/01/30 03:18:03 Job still running ...
2023/01/30 03:18:33 Job still running ...
2023/01/30 03:19:03 Job still running ...
2023/01/30 03:19:33 Job still running ...
2023/01/30 03:20:03 Job still running ...
2023/01/30 03:20:33 Job still running ...
2023/01/30 03:21:03 Job still running ...
2023/01/30 03:21:33 Job still running ...
2023/01/30 03:22:03 Job still running ...
2023/01/30 03:22:33 Job still running ...
2023/01/30 03:23:03 Job still running ...
2023/01/30 03:23:33 Job still running ...
2023/01/30 03:24:03 Job still running ...
2023/01/30 03:24:33 Job still running ...
2023/01/30 03:25:03 Job still running ...
2023/01/30 03:25:33 Job still running ...
2023/01/30 03:26:03 Job still running ...
2023/01/30 03:26:34 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-29_19_17_32-17273083713657177367 failed
--- FAIL: TestXLang_Partition (580.75s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3262.668s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675045964941730576
--- FAIL: TestBigQueryIO_BasicWriteRead (4.23s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39663 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RfvPTndaui" is_bounded:BOUNDED windowing_strategy_id:"w0@RfvPTndaui"}} windowing_strategies:{key:"w0@RfvPTndaui" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RfvPTndaui" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RfvPTndaui" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RfvPTndaui" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675045964941730576\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RfvPTndaui"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:39663 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@RfvPTndaui" is_bounded:BOUNDED windowing_strategy_id:"w0@RfvPTndaui"}} windowing_strategies:{key:"w0@RfvPTndaui" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@RfvPTndaui" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@RfvPTndaui" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@RfvPTndaui" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675045964941730576\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"RfvPTndaui"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 22 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000714140})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000714140})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7980?, 0xc000593680?}, {0x110f943, 0x39}, {0xc0000ee0c0?, 0xa969c0?, 0x1?}, {0xc0003f6de0, 0xf}, 0xc000179d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a7920?, 0xc000593680?}, {0xc0007224e0, 0x52}, {0x1?}, {0xc000179ea8, 0x2, 0x7f6def751448?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f6de0, 0xf}, {0xc0007224e0, 0x52}, {0xe96fa0, 0xc000042450})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000103040)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000103040, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.263s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ab017271a7cb15ec121d60d61fd0f29b0a085c99802acb295c274398ec894de1
Deleted: sha256:893fc36e2447b8aebf42bf34969e52c71e7340c802841bf296f55f4d1e8cc796
Deleted: sha256:58db0d36a02f7bb73a1c68b13f10c37da3da3bf211788edb4f5ac2bfeee945d6
Deleted: sha256:7fba5a3791e17fc43d9cda09de33b537836d975decf7fef54951b5882efdabd2
Deleted: sha256:3cb9a78d46181353fe2aa342993a3c84c82aeed68db17170facff890ca5233bc
Deleted: sha256:4a439571f57deb7811f0951d517ceba5bc37d139f813614db3d13bc043311d6d
Deleted: sha256:ec3252f2829056c1f6a6b871278b556fa1a9de925224c7f7495605578f4e79d7
Deleted: sha256:f08571159eb3a4d495cfdb8ef7cad52fdc281618c66c0b0d8f5dbda1c0e48599
Deleted: sha256:ed43af799ad667b86fabd33e78354239557dd538b87d4b7901d7e82b9877327d
Deleted: sha256:194c5a7518ff583abfea8d577938a36415fe4d630b9fa91cc32df2c18c7b44b3
Deleted: sha256:b411cec4d119100f23e034aa9d18ff7e9eddbb115c6e69ab5565e26780ada6e8
Deleted: sha256:2c6636b0a67c7f0708f296258d5d8a786e87a4e22f77ecbc71ddd08e8339668c
Deleted: sha256:610d2f12248264a152d41cbe11ae70332492998cb2f219c87c49e1207fa9c5b5
Deleted: sha256:0cb33abeafd0249b13143556fff6cafc8c81dfd974d870140ac23b83d76b14ef
Deleted: sha256:513aa1968dcbad1d8d723aeca061237a3c4fe79f724deb6377f2e75ea7a47014
Deleted: sha256:772a1280575c9bbdb6157371b355311c86e9b9e53ba08edd8bb74b44e03ac1e4
Deleted: sha256:102df14ba619c675796ec65b8a83348ca38944e56324e1dab7503c5033a4338d
Deleted: sha256:52019c946a4caeb7eefc15c5b00f1e7957f3dd31d22d0ba386d932b41ae3d0e1
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ab017271a7cb15ec121d60d61fd0f29b0a085c99802acb295c274398ec894de1
  Associated tags:
 - 20230130-023209
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230130-023209].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:ab017271a7cb15ec121d60d61fd0f29b0a085c99802acb295c274398ec894de1].
$ rm -rf /tmp/tmp.rIMdwErIW9
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230130022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:353f8b4456966473d110d8079d7b95a2aeacaeb69715af34916371c522fee1bb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130022045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130022045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230130022045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:8401279dbea56ff4ef5488a9596baffeaa569eb48ff988320e9d70cced839398].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1533711.
Stopping expansion service pid: 1533712.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 6m 44s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1227

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1227/display/redirect>

Changes:


------------------------------------------
[...truncated 1015.32 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21404/go-8-1675027169805392625/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-203211"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129202044"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-203211"
      }
    ]
  },
  "name": "go-testxlang_partition-86",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/29 21:19:39 Submitted job: 2023-01-29_13_19_38-10779876241232932130
2023/01/29 21:19:39 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-29_13_19_38-10779876241232932130?project=apache-beam-testing
2023/01/29 21:19:39 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-29_13_19_38-10779876241232932130
2023/01/29 21:19:39 Job state: JOB_STATE_PENDING ...
2023/01/29 21:20:09 Job still running ...
2023/01/29 21:20:39 Job still running ...
2023/01/29 21:21:09 Job still running ...
2023/01/29 21:21:39 Job still running ...
2023/01/29 21:22:09 Job still running ...
2023/01/29 21:22:39 Job still running ...
2023/01/29 21:23:09 Job still running ...
2023/01/29 21:23:39 Job still running ...
2023/01/29 21:24:09 Job still running ...
2023/01/29 21:24:39 Job still running ...
2023/01/29 21:25:09 Job still running ...
2023/01/29 21:25:39 Job still running ...
2023/01/29 21:26:09 Job still running ...
2023/01/29 21:26:39 Job still running ...
2023/01/29 21:27:09 Job still running ...
2023/01/29 21:27:39 Job still running ...
2023/01/29 21:28:09 Job still running ...
2023/01/29 21:28:39 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-29_13_19_38-10779876241232932130 failed
--- FAIL: TestXLang_Partition (580.41s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3384.317s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675024368971824523
--- FAIL: TestBigQueryIO_BasicWriteRead (4.31s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42677 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@VgEpZLxsDS" is_bounded:BOUNDED windowing_strategy_id:"w0@VgEpZLxsDS"}} windowing_strategies:{key:"w0@VgEpZLxsDS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@VgEpZLxsDS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@VgEpZLxsDS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@VgEpZLxsDS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675024368971824523\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"VgEpZLxsDS"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:42677 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@VgEpZLxsDS" is_bounded:BOUNDED windowing_strategy_id:"w0@VgEpZLxsDS"}} windowing_strategies:{key:"w0@VgEpZLxsDS" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@VgEpZLxsDS" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@VgEpZLxsDS" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@VgEpZLxsDS" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675024368971824523\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"VgEpZLxsDS"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 11 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000584bc0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000584bc0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004807c0?, 0xc0000bc050?}, {0x110f943, 0x39}, {0xc00053c0c0?, 0xa969c0?, 0x1?}, {0xc0003f3b60, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000480760?, 0xc0000bc050?}, {0xc00010eba0, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0xe56760?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0003f3b60, 0xf}, {0xc00010eba0, 0x52}, {0xe96fa0, 0xc0004aa248})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc00035dba0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc00035dba0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.343s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.031s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a95afdae06ec9e5323c23e3070f60d57a460b2663a76c3a6006bcc94c35a608d
  Associated tags:
 - 20230129-203211
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-203211
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-203211].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:a95afdae06ec9e5323c23e3070f60d57a460b2663a76c3a6006bcc94c35a608d].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9c42e846cc2f94cd4bfa80c9671b05a6a4cd64c0d6f769f908ffeae2f4bf95bb]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9c42e846cc2f94cd4bfa80c9671b05a6a4cd64c0d6f769f908ffeae2f4bf95bb])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9c42e846cc2f94cd4bfa80c9671b05a6a4cd64c0d6f769f908ffeae2f4bf95bb
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:9c42e846cc2f94cd4bfa80c9671b05a6a4cd64c0d6f769f908ffeae2f4bf95bb].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129202044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:675cf790ceffb26d8ec514e1cd3ae15eeaf210b612201d59690d5da6b398de1c]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129202044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:675cf790ceffb26d8ec514e1cd3ae15eeaf210b612201d59690d5da6b398de1c])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:675cf790ceffb26d8ec514e1cd3ae15eeaf210b612201d59690d5da6b398de1c
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:675cf790ceffb26d8ec514e1cd3ae15eeaf210b612201d59690d5da6b398de1c].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 50s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1226

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1226/display/redirect>

Changes:


------------------------------------------
[...truncated 1017.27 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test10428/go-8-1675005596548892688/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129142045"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209"
      }
    ]
  },
  "name": "go-testxlang_partition-394",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/29 15:20:05 Submitted job: 2023-01-29_07_20_05-4567127266482382781
2023/01/29 15:20:05 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-29_07_20_05-4567127266482382781?project=apache-beam-testing
2023/01/29 15:20:05 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-29_07_20_05-4567127266482382781
2023/01/29 15:20:05 Job state: JOB_STATE_PENDING ...
2023/01/29 15:20:35 Job still running ...
2023/01/29 15:21:05 Job still running ...
2023/01/29 15:21:35 Job still running ...
2023/01/29 15:22:05 Job still running ...
2023/01/29 15:22:36 Job still running ...
2023/01/29 15:23:06 Job still running ...
2023/01/29 15:23:36 Job still running ...
2023/01/29 15:24:06 Job still running ...
2023/01/29 15:24:36 Job still running ...
2023/01/29 15:25:06 Job still running ...
2023/01/29 15:25:36 Job still running ...
2023/01/29 15:26:06 Job still running ...
2023/01/29 15:26:36 Job still running ...
2023/01/29 15:27:06 Job still running ...
2023/01/29 15:27:36 Job still running ...
2023/01/29 15:28:06 Job still running ...
2023/01/29 15:28:36 Job still running ...
2023/01/29 15:29:06 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-29_07_20_05-4567127266482382781 failed
--- FAIL: TestXLang_Partition (580.41s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3412.336s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675002767720527392
--- FAIL: TestBigQueryIO_BasicWriteRead (4.29s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46193 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aSgzSnJqkF" is_bounded:BOUNDED windowing_strategy_id:"w0@aSgzSnJqkF"}} windowing_strategies:{key:"w0@aSgzSnJqkF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aSgzSnJqkF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aSgzSnJqkF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aSgzSnJqkF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675002767720527392\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aSgzSnJqkF"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:46193 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@aSgzSnJqkF" is_bounded:BOUNDED windowing_strategy_id:"w0@aSgzSnJqkF"}} windowing_strategies:{key:"w0@aSgzSnJqkF" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@aSgzSnJqkF" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@aSgzSnJqkF" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@aSgzSnJqkF" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1675002767720527392\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"aSgzSnJqkF"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 21 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00049f040})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00049f040})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc00011aa80?, 0xc0000bc280?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc000125050, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc00011aa20?, 0xc0000bc280?}, {0xc000542360, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7fc1a9457fb8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000125050, 0xf}, {0xc000542360, 0x52}, {0xe96fa0, 0xc0003f8150})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001031e0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001031e0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.319s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.033s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.032s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1f2683c5f324d153225ebce97b2feefecf0185c75880d2026b5798eaf323c355
Deleted: sha256:136312d84995b9cf03b548400e1bea1fc33c148aeaba97dd6b77485f740732d5
Deleted: sha256:24c1cbe1239c6bb054a0ed078c75d5fc1040c83043f152125ec0ead742eee842
Deleted: sha256:e59d26a82bdbba30a9450e70149ba3d1762f42d47cf2b37cb31459e9a33d4528
Deleted: sha256:c8cb61b43f8a704e1bd8769ef81e292a45dd7d20efde818facf936da0b2c3282
Deleted: sha256:99766837215800d27df956bc10a0898b37aef64bb891254ea0f6dac98450449f
Deleted: sha256:1eed04d80e8e45ec7d2d0a18bf1d1e2761e1c979b6185fc4225406d38b29b671
Deleted: sha256:cf563d278d2432805cd08997628bf2f35c4afd47cf86bb8968edf22b96a05cbd
Deleted: sha256:df5f7886799ff77ebbfff5a39d491a182fb8d77d62109d84b2b3af12755fb84d
Deleted: sha256:1402c9e533a466b8f05f981a4481ebeddc31aa7ed36e21bb2b743278560e27ff
Deleted: sha256:14754b403b29cf23e21d435dbd658663fbf97ce61a5c35a119a20df3958fefdd
Deleted: sha256:084ae219d160f1d20ff155d728e7851fdbef9d01e5e16f766b9990d9ae629989
Deleted: sha256:4d4a9ff85951b551caca45bef4480e11f506dcca0c34d24c0c7ed9ed959f9800
Deleted: sha256:055475bb25ec618191ae2bb488b30d8d96761099f4d94fac8449135d40448f73
Deleted: sha256:8d386dd9cbd7530e34c44c62a85914c441b83f13220d6ba146424ae7e31d65db
Deleted: sha256:968408e8a7c4874e978e75fccfe64fcc12d30656a481ef451a6db343044d506f
Deleted: sha256:7f83e2d7e9a4d2f817e6c172415a88178aab921e41ee0ba2148f997ef333985e
Deleted: sha256:dd3f45b40409ca8283d982f7cccc714fba821025fa3412b60e5fe21da71c2b73
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1f2683c5f324d153225ebce97b2feefecf0185c75880d2026b5798eaf323c355
  Associated tags:
 - 20230129-143209
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-143209].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:1f2683c5f324d153225ebce97b2feefecf0185c75880d2026b5798eaf323c355].
$ rm -rf /tmp/tmp.oQLjXIqAHP
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129142045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:dc1a9fd4795de8df59037154204807c9f1e59acc2b7f743cdfc99c55feb64986].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129142045
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129142045]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129142045] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:d9cb1ef288b2cc444001018bb5b5989f5eb025f14695eeb4456250456cba70b1].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1292729.
Stopping expansion service pid: 1292730.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 9m 17s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1225

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1225/display/redirect>

Changes:


------------------------------------------
[...truncated 966.19 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test32156/go-8-1674983643570280325/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129082044"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206"
      }
    ]
  },
  "name": "go-testxlang_partition-916",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/29 09:14:12 Submitted job: 2023-01-29_01_14_11-13583316849607579738
2023/01/29 09:14:12 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-29_01_14_11-13583316849607579738?project=apache-beam-testing
2023/01/29 09:14:12 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-29_01_14_11-13583316849607579738
2023/01/29 09:14:12 Job state: JOB_STATE_PENDING ...
2023/01/29 09:14:42 Job still running ...
2023/01/29 09:15:12 Job still running ...
2023/01/29 09:15:42 Job still running ...
2023/01/29 09:16:12 Job still running ...
2023/01/29 09:16:42 Job still running ...
2023/01/29 09:17:12 Job still running ...
2023/01/29 09:17:42 Job still running ...
2023/01/29 09:18:12 Job still running ...
2023/01/29 09:18:42 Job still running ...
2023/01/29 09:19:12 Job still running ...
2023/01/29 09:19:42 Job still running ...
2023/01/29 09:20:13 Job still running ...
2023/01/29 09:20:43 Job still running ...
2023/01/29 09:21:13 Job still running ...
2023/01/29 09:21:43 Job still running ...
2023/01/29 09:22:13 Job still running ...
2023/01/29 09:22:43 Job still running ...
2023/01/29 09:23:13 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-29_01_14_11-13583316849607579738 failed
--- FAIL: TestXLang_Partition (580.07s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3065.679s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674981161114651759
--- FAIL: TestBigQueryIO_BasicWriteRead (4.32s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38125 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@iJACKOPqew" is_bounded:BOUNDED windowing_strategy_id:"w0@iJACKOPqew"}} windowing_strategies:{key:"w0@iJACKOPqew" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@iJACKOPqew" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@iJACKOPqew" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@iJACKOPqew" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674981161114651759\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"iJACKOPqew"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:38125 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@iJACKOPqew" is_bounded:BOUNDED windowing_strategy_id:"w0@iJACKOPqew"}} windowing_strategies:{key:"w0@iJACKOPqew" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@iJACKOPqew" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@iJACKOPqew" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@iJACKOPqew" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674981161114651759\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"iJACKOPqew"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 26 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc000662e00})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc000662e00})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a6ec0?, 0xc0000bd680?}, {0x110f943, 0x39}, {0xc00015a0c0?, 0xa969c0?, 0x1?}, {0xc000486d00, 0xf}, 0xc000155d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a6e60?, 0xc0000bd680?}, {0xc00004c480, 0x52}, {0x1?}, {0xc000155ea8, 0x2, 0x7f4ff060ec30?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000486d00, 0xf}, {0xc00004c480, 0x52}, {0xe96fa0, 0xc000650090})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cab60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cab60, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.353s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.041s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.030s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.033s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:180c354523c1689858e4885b19086841f6f4a6e3fb325fac2a88a997fb3cdbd8
Deleted: sha256:98ce4a04245a3694a08247fb5ea0e245f0577a875afab6150b86da288a70bd1f
Deleted: sha256:39dfbd3a2999a96c897128c7a7693c4469a6bf096cf0b3eebba6cc627b02d08f
Deleted: sha256:c850f296a02fb811c8d41109ac0a503b7f720d95c2d339e1ac36d2717b4148de
Deleted: sha256:95076b00da4fb78993c80582281ca536130118ef9c18aada7a6643495918c769
Deleted: sha256:949107c54321feb202a21d9e70c9766e8a3686731fd8bcb489f6eebbc5a07100
Deleted: sha256:76684f33f4b9aac1fd059ab62f36a017af7c89998d945f20bf6c115184db2a94
Deleted: sha256:4bc6f6a9ae63b6abd912ffcc4ef7c735de837383d1e58152d26b991764242917
Deleted: sha256:202f0caf394d55237d6a7b7bbe078de6ee5a511648dc42879a257ffdebbe8c08
Deleted: sha256:6835b63f4ef99397616823ba3e2b06c4c0e3aae905418f02891cdbc7d8e9ffa1
Deleted: sha256:2b2302133debd0ca2837664c9c6ecc972589351dd5234dc633a5ebe2380c5de1
Deleted: sha256:54b25ff22db932f08c44d597f6480e1754a2115f5cf5cc5ea1677a0bf55a275e
Deleted: sha256:e6ddf8ba1a97f525d2cbe5959dfaa5a10fbbd80f625ffe2ce8cc8b5caf274e47
Deleted: sha256:3ab336858f198f5a9c530e6349757abdd159207ac367f5c4a59edb9ddd8735de
Deleted: sha256:b0698878714715ec18d1b7371b5fca3e58311f8aa1e8cbc72a1237c43801100e
Deleted: sha256:f1ade7ec9d73732d6060b0a6e8bd5ac2bf54201617d31950d9775bc17b8e91d4
Deleted: sha256:302072f7918310f08ff46478a542d88e9f6b83781ebc2d7a6524d526818933bd
Deleted: sha256:26f568e0dac72c1f344dfda607b214029c94385dfd08d4cbf9cc9f42cd77e8d9
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:180c354523c1689858e4885b19086841f6f4a6e3fb325fac2a88a997fb3cdbd8
  Associated tags:
 - 20230129-083206
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-083206].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:180c354523c1689858e4885b19086841f6f4a6e3fb325fac2a88a997fb3cdbd8].
$ rm -rf /tmp/tmp.e01kmX3n43
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129082044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:7ade95c41fd8c3feeb918648fb584f7d2182ff1c7c9d5ff5d05cf1c04713d44e].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129082044
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129082044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129082044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:f3a2644fd2738219320d1c510fff6c673995dc4903185c6b4ba35bf0bcdbf894].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 1175143.
Stopping expansion service pid: 1175144.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 3m 26s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1224

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1224/display/redirect>

Changes:


------------------------------------------
[...truncated 997.66 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test25618/go-8-1674962299001367109/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-023200"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129022044"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-023200"
      }
    ]
  },
  "name": "go-testxlang_partition-135",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/29 03:18:27 Submitted job: 2023-01-28_19_18_26-7859010936492861746
2023/01/29 03:18:27 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-28_19_18_26-7859010936492861746?project=apache-beam-testing
2023/01/29 03:18:27 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-28_19_18_26-7859010936492861746
2023/01/29 03:18:27 Job state: JOB_STATE_PENDING ...
2023/01/29 03:18:57 Job still running ...
2023/01/29 03:19:27 Job still running ...
2023/01/29 03:19:57 Job still running ...
2023/01/29 03:20:27 Job still running ...
2023/01/29 03:20:57 Job still running ...
2023/01/29 03:21:27 Job still running ...
2023/01/29 03:21:57 Job still running ...
2023/01/29 03:22:27 Job still running ...
2023/01/29 03:22:57 Job still running ...
2023/01/29 03:23:27 Job still running ...
2023/01/29 03:23:58 Job still running ...
2023/01/29 03:24:28 Job still running ...
2023/01/29 03:24:58 Job still running ...
2023/01/29 03:25:28 Job still running ...
2023/01/29 03:25:58 Job still running ...
2023/01/29 03:26:28 Job still running ...
2023/01/29 03:26:58 Job still running ...
2023/01/29 03:27:28 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-28_19_18_26-7859010936492861746 failed
--- FAIL: TestXLang_Partition (579.78s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3325.417s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674959556422631779
--- FAIL: TestBigQueryIO_BasicWriteRead (4.19s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44489 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZOHVyZgPms" is_bounded:BOUNDED windowing_strategy_id:"w0@ZOHVyZgPms"}} windowing_strategies:{key:"w0@ZOHVyZgPms" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZOHVyZgPms" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZOHVyZgPms" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZOHVyZgPms" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674959556422631779\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZOHVyZgPms"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:44489 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ZOHVyZgPms" is_bounded:BOUNDED windowing_strategy_id:"w0@ZOHVyZgPms"}} windowing_strategies:{key:"w0@ZOHVyZgPms" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ZOHVyZgPms" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ZOHVyZgPms" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ZOHVyZgPms" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674959556422631779\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ZOHVyZgPms"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 35 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00002ab40})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00002ab40})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0000a7720?, 0xc0000bd9f0?}, {0x110f943, 0x39}, {0xc000194000?, 0xa969c0?, 0x1?}, {0xc00048cca0, 0xf}, 0xc0000ebd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0000a76c0?, 0xc0000bd9f0?}, {0xc00064e420, 0x52}, {0x1?}, {0xc0000ebea8, 0x2, 0x7f14267f4860?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc00048cca0, 0xf}, {0xc00064e420, 0x52}, {0xe96fa0, 0xc00048dfb0})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000498820)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000498820, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.219s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.044s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.029s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:747f85443213bd530316ed8aaddfab2a63ff6446b5a1a66f1dac884d84e25265
  Associated tags:
 - 20230129-023200
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-023200
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230129-023200].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:747f85443213bd530316ed8aaddfab2a63ff6446b5a1a66f1dac884d84e25265].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129022044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbced6c87d3dff9841658a5a2eab2e3d517ce8db5548442550bbcb404b65a243]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230129022044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbced6c87d3dff9841658a5a2eab2e3d517ce8db5548442550bbcb404b65a243])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbced6c87d3dff9841658a5a2eab2e3d517ce8db5548442550bbcb404b65a243
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:fbced6c87d3dff9841658a5a2eab2e3d517ce8db5548442550bbcb404b65a243].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129022044]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9b18f9412edc6725f3471af3672fd3099eed77b5f0373d5832b6e576bd9f33e4]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230129022044] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9b18f9412edc6725f3471af3672fd3099eed77b5f0373d5832b6e576bd9f33e4])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9b18f9412edc6725f3471af3672fd3099eed77b5f0373d5832b6e576bd9f33e4
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:9b18f9412edc6725f3471af3672fd3099eed77b5f0373d5832b6e576bd9f33e4].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 39s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/7zfsqsx2t6nc6

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1223

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1223/display/redirect>

Changes:


------------------------------------------
[...truncated 1004.34 KB...]
      {
        "autoscalingSettings": {},
        "ipConfiguration": "WORKER_IP_UNSPECIFIED",
        "kind": "harness",
        "numWorkers": 1,
        "packages": [
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/worker",
            "name": "worker"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar",
            "name": "icedtea-sound-5xFkOD7aUmX8Jiw7lPqhn75zkNGCyUOfOuqi2rClWKM.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar",
            "name": "jaccess-Rlp7GfuSFOBCBGdO8af2XxrTz5LqaQqwSMAXumdbHN0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar",
            "name": "nashorn-1iQRhJvU2nRCSB4ucg6f4b69TGiwE1yq0_LGG2MU5N0.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar",
            "name": "cldrdata-MTK3mMuUzlWYlYkweGQNzI7dFpuLG0_8F8oxT0khQDc.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar",
            "name": "dnsns-YTF3f6B-OG4FmXLRf2ckHBi4VJnspBZTyIQCz-6Spwk.jar"
          },
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test4143/go-8-1674940706648464155/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-203212"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128202043"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-203212"
      }
    ]
  },
  "name": "go-testxlang_partition-466",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/28 21:18:34 Submitted job: 2023-01-28_13_18_34-1308255575734532287
2023/01/28 21:18:34 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-28_13_18_34-1308255575734532287?project=apache-beam-testing
2023/01/28 21:18:34 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-28_13_18_34-1308255575734532287
2023/01/28 21:18:34 Job state: JOB_STATE_PENDING ...
2023/01/28 21:19:04 Job still running ...
2023/01/28 21:19:35 Job still running ...
2023/01/28 21:20:05 Job still running ...
2023/01/28 21:20:35 Job still running ...
2023/01/28 21:21:05 Job still running ...
2023/01/28 21:21:35 Job still running ...
2023/01/28 21:22:05 Job still running ...
2023/01/28 21:22:35 Job still running ...
2023/01/28 21:23:05 Job still running ...
2023/01/28 21:23:35 Job still running ...
2023/01/28 21:24:05 Job still running ...
2023/01/28 21:24:35 Job still running ...
2023/01/28 21:25:05 Job still running ...
2023/01/28 21:25:35 Job still running ...
2023/01/28 21:26:05 Job still running ...
2023/01/28 21:26:35 Job still running ...
2023/01/28 21:27:05 Job still running ...
2023/01/28 21:27:35 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-28_13_18_34-1308255575734532287 failed
--- FAIL: TestXLang_Partition (579.44s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3320.063s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674937969182642014
--- FAIL: TestBigQueryIO_BasicWriteRead (4.31s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36005 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BcXzIFOtle" is_bounded:BOUNDED windowing_strategy_id:"w0@BcXzIFOtle"}} windowing_strategies:{key:"w0@BcXzIFOtle" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BcXzIFOtle" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BcXzIFOtle" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BcXzIFOtle" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674937969182642014\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BcXzIFOtle"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:36005 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@BcXzIFOtle" is_bounded:BOUNDED windowing_strategy_id:"w0@BcXzIFOtle"}} windowing_strategies:{key:"w0@BcXzIFOtle" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@BcXzIFOtle" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@BcXzIFOtle" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@BcXzIFOtle" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674937969182642014\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"BcXzIFOtle"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 38 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00015ec80})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00015ec80})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004c50c0?, 0xc000139a90?}, {0x110f943, 0x39}, {0xc000208000?, 0xa969c0?, 0x1?}, {0xc000131d60, 0xf}, 0xc000205d20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004c5060?, 0xc000139a90?}, {0xc0004d63c0, 0x52}, {0x1?}, {0xc000205ea8, 0x2, 0x7fd2b17805b8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000131d60, 0xf}, {0xc0004d63c0, 0x52}, {0xe96fa0, 0xc0001a9080})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0000cab60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0000cab60, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.343s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.034s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.029s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.032s
FAIL
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:0c58e11b3eecb859c2ff1805ada2053be8c2da8f921994a7caed70577f5a8933
  Associated tags:
 - 20230128-203212
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-203212
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-203212].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:0c58e11b3eecb859c2ff1805ada2053be8c2da8f921994a7caed70577f5a8933].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128202043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:551a9e7e778e5f68225634a9f73f0c6617a5c154e721aa65829b5af730dd8646]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128202043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:551a9e7e778e5f68225634a9f73f0c6617a5c154e721aa65829b5af730dd8646])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:551a9e7e778e5f68225634a9f73f0c6617a5c154e721aa65829b5af730dd8646
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:551a9e7e778e5f68225634a9f73f0c6617a5c154e721aa65829b5af730dd8646].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128202043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25328f974c97f46c617c278a56bcfb400aa9b4c311e0ecddc45e14229b1d9db0]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128202043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25328f974c97f46c617c278a56bcfb400aa9b4c311e0ecddc45e14229b1d9db0])].
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25328f974c97f46c617c278a56bcfb400aa9b4c311e0ecddc45e14229b1d9db0
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:25328f974c97f46c617c278a56bcfb400aa9b4c311e0ecddc45e14229b1d9db0].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 46s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1222

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1222/display/redirect>

Changes:


------------------------------------------
[...truncated 1003.75 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test21435/go-8-1674919125628154087/xlang/beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar",
            "name": "beam-sdks-java-testing-expansion-service-testExpansionService-2.46.0-SNAPSHOT-q90v24rQpV7XzD_n2_OUb6jJaCizqkHsbY08YsrPS84.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128142047"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230"
      }
    ]
  },
  "name": "go-testxlang_partition-283",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/28 15:18:53 Submitted job: 2023-01-28_07_18_53-7183214047287958759
2023/01/28 15:18:53 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-28_07_18_53-7183214047287958759?project=apache-beam-testing
2023/01/28 15:18:53 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-28_07_18_53-7183214047287958759
2023/01/28 15:18:53 Job state: JOB_STATE_PENDING ...
2023/01/28 15:19:23 Job still running ...
2023/01/28 15:19:53 Job still running ...
2023/01/28 15:20:24 Job still running ...
2023/01/28 15:20:54 Job still running ...
2023/01/28 15:21:24 Job still running ...
2023/01/28 15:21:54 Job still running ...
2023/01/28 15:22:24 Job still running ...
2023/01/28 15:22:54 Job still running ...
2023/01/28 15:23:24 Job still running ...
2023/01/28 15:23:54 Job still running ...
2023/01/28 15:24:24 Job still running ...
2023/01/28 15:24:54 Job still running ...
2023/01/28 15:25:24 Job still running ...
2023/01/28 15:25:54 Job still running ...
2023/01/28 15:26:24 Job still running ...
2023/01/28 15:26:54 Job still running ...
2023/01/28 15:27:24 Job still running ...
2023/01/28 15:27:54 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-28_07_18_53-7183214047287958759 failed
--- FAIL: TestXLang_Partition (579.34s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3320.613s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674916387512812175
--- FAIL: TestBigQueryIO_BasicWriteRead (4.30s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37219 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wviYFaLQEA" is_bounded:BOUNDED windowing_strategy_id:"w0@wviYFaLQEA"}} windowing_strategies:{key:"w0@wviYFaLQEA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wviYFaLQEA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wviYFaLQEA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wviYFaLQEA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674916387512812175\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wviYFaLQEA"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:37219 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@wviYFaLQEA" is_bounded:BOUNDED windowing_strategy_id:"w0@wviYFaLQEA"}} windowing_strategies:{key:"w0@wviYFaLQEA" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@wviYFaLQEA" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@wviYFaLQEA" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@wviYFaLQEA" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674916387512812175\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"wviYFaLQEA"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 40 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc0002fa780})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc0002fa780})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc0004c6980?, 0xc0000d9680?}, {0x110f943, 0x39}, {0xc000236000?, 0xa969c0?, 0x1?}, {0xc000137bc0, 0xf}, 0xc0001add20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc0004c6920?, 0xc0000d9680?}, {0xc0004cc360, 0x52}, {0x1?}, {0xc0001adea8, 0x2, 0x7f41803185f8?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc000137bc0, 0xf}, {0xc0004cc360, 0x52}, {0xe96fa0, 0xc000158f70})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc000334b60)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc000334b60, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.331s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.036s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.033s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:de71169cea1c17182077c3a747a23e0dd09c7e1441047d6c1f2c254f387ea750
Deleted: sha256:54f2fe9912b5baba8945627f0154834d2a6ecbba22bf91cdd97b4429074f6202
Deleted: sha256:295813be0755ed2e9ce3347259c60d9258937630a492c7345ce9660224b64803
Deleted: sha256:37499517362df28b91e05994bc4e81d274f7535dd9328ebc7d288028d7d29ed9
Deleted: sha256:1d5d89787a2f354e47f518ca83290d4317c0b19cc27eb6bcb362382eb0800cfa
Deleted: sha256:6d205e8ade90445fb98143a409c86ff91282eab5514f50181c9c9b7edff35914
Deleted: sha256:042b54062b1119d35777ffe4e76359ff895cdbf727ce8f576bb751720659a9c8
Deleted: sha256:8a470d17cfde308351e66b921cfb4644cc159fb90aa4735dc8c9fe5a702877f0
Deleted: sha256:c1a177a8a8a8bf711fc4314ea22474e7d85e8935c0647cc5ba4c87d936dd626c
Deleted: sha256:a27f214a4b6723217bbe7da94946c2bd0d18813261167f4195183f451921c09c
Deleted: sha256:5b9d26abd775ecf11f70d46d3307f17779061b0a69e1f287b0f70b0dfbcc485e
Deleted: sha256:f61514849cfd57e02a76255e42654647798ab20a47215f936a3bde9989d9188e
Deleted: sha256:2dfb234b443d69dc91706258a657d1a4f794053758f788485d9fe67a65d76191
Deleted: sha256:8561005c9b1d11e804d7c335845d91a308d485a7e8b575f9c0edec82c45f1c4c
Deleted: sha256:506341a4b22dbe2fabbffcff8241f1d9dc4d69729d6fde5581ae861fdf22b829
Deleted: sha256:c4f9dec6ede2953ba5940a6b21b5cfff3311af6cda564bd8f756c2fda97e40fa
Deleted: sha256:bd7cde0ac680766f0143a39b1f595520233dfc14cda590f6420df0852fda6178
Deleted: sha256:df5b00cfe6c4f475f5c9b76133dcf9c40a921e5feb3ae561e3bbf5cbcd5230ad
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:de71169cea1c17182077c3a747a23e0dd09c7e1441047d6c1f2c254f387ea750
  Associated tags:
 - 20230128-143230
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-143230].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:de71169cea1c17182077c3a747a23e0dd09c7e1441047d6c1f2c254f387ea750].
$ rm -rf /tmp/tmp.gromYchnss
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:4687bbd4e42693673ca441b22799281d7d92e08e23d24ae631ce29472ea8f4b1].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128142047
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128142047]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128142047] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:4765c3cfea4fa99d00b8cd7a543d60495ba642f2098d0348dae3240f9ffcc601].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 831508.
Skipping invalid pid: 831509.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 8m 4s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

Publishing build scan...
https://gradle.com/s/2gwawefs4piji

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


Build failed in Jenkins: beam_PostCommit_XVR_GoUsingJava_Dataflow #1221

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/1221/display/redirect?page=changes>

Changes:

[Robert Bradshaw] Fix website.


------------------------------------------
[...truncated 1020.61 KB...]
          {
            "location": "gs://temp-storage-for-end-to-end-tests/staging-validatesrunner-test/test15105/go-8-1674897477390525858/xlang/localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar",
            "name": "localedata-Nuzln2shadVmT-PppqaNc7GHBbUyMUb9pXsJTjRiAzs.jar"
          }
        ],
        "sdkHarnessContainerImages": [
          {
            "containerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209"
          },
          {
            "containerImage": "us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128082043"
          }
        ],
        "workerHarnessContainerImage": "us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209"
      }
    ]
  },
  "name": "go-testxlang_partition-644",
  "projectId": "apache-beam-testing",
  "type": "JOB_TYPE_BATCH"
}
2023/01/28 09:18:06 Submitted job: 2023-01-28_01_18_05-16972770867707032666
2023/01/28 09:18:06 Console: https://console.cloud.google.com/dataflow/jobs/us-central1/2023-01-28_01_18_05-16972770867707032666?project=apache-beam-testing
2023/01/28 09:18:06 Logs: https://console.cloud.google.com/logs/viewer?project=apache-beam-testing&resource=dataflow_step%2Fjob_id%2F2023-01-28_01_18_05-16972770867707032666
2023/01/28 09:18:06 Job state: JOB_STATE_PENDING ...
2023/01/28 09:18:36 Job still running ...
2023/01/28 09:19:06 Job still running ...
2023/01/28 09:19:36 Job still running ...
2023/01/28 09:20:06 Job still running ...
2023/01/28 09:20:36 Job still running ...
2023/01/28 09:21:06 Job still running ...
2023/01/28 09:21:36 Job still running ...
2023/01/28 09:22:06 Job still running ...
2023/01/28 09:22:36 Job still running ...
2023/01/28 09:23:06 Job still running ...
2023/01/28 09:23:36 Job still running ...
2023/01/28 09:24:06 Job still running ...
2023/01/28 09:24:36 Job still running ...
2023/01/28 09:25:06 Job still running ...
2023/01/28 09:25:36 Job still running ...
2023/01/28 09:26:06 Job still running ...
2023/01/28 09:26:36 Job still running ...
2023/01/28 09:27:07 Job still running ...
    ptest.go:108: Failed to execute job: Job 2023-01-28_01_18_05-16972770867707032666 failed
--- FAIL: TestXLang_Partition (579.98s)
FAIL
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/xlang	3294.449s
=== RUN   TestBigQueryIO_BasicWriteRead
    bigquery_test.go:213: Created BigQuery table apache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674894766078736063
--- FAIL: TestBigQueryIO_BasicWriteRead (4.21s)
panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40865 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ODzYEFkVGG" is_bounded:BOUNDED windowing_strategy_id:"w0@ODzYEFkVGG"}} windowing_strategies:{key:"w0@ODzYEFkVGG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ODzYEFkVGG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ODzYEFkVGG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ODzYEFkVGG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674894766078736063\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ODzYEFkVGG"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)
 [recovered]
	panic: 	tried cross-language for beam:transform:org.apache.beam:schemaio_bigquery_write:v1 against localhost:40865 and failed
	expanding external transform
	expanding transform with ExpansionRequest: components:{pcollections:{key:"n2" value:{unique_name:"n2" coder_id:"c0@ODzYEFkVGG" is_bounded:BOUNDED windowing_strategy_id:"w0@ODzYEFkVGG"}} windowing_strategies:{key:"w0@ODzYEFkVGG" value:{window_fn:{urn:"beam:window_fn:global_windows:v1"} merge_status:NON_MERGING window_coder_id:"c1@ODzYEFkVGG" trigger:{default:{}} accumulation_mode:DISCARDING output_time:END_OF_WINDOW closing_behavior:EMIT_IF_NONEMPTY on_time_behavior:FIRE_IF_NONEMPTY environment_id:"go"}} coders:{key:"c0@ODzYEFkVGG" value:{spec:{urn:"beam:coder:row:v1" payload:"\n\r\n\x07counter\x1a\x02\x10\x04\nZ\n\trand_data\x1aM2K\nI\n\n\n\x04flip\x1a\x02\x10\x08\n\t\n\x03num\x1a\x02\x10\x04\n\n\n\x04word\x1a\x02\x10\x07\x12$293279a3-cab2-4082-b6be-1729f646ba84\x12$40dfa07a-fadd-4e7a-ac47-7534633021ad"}}} coders:{key:"c1@ODzYEFkVGG" value:{spec:{urn:"beam:coder:global_window:v1"}}}} transform:{unique_name:"External" spec:{urn:"beam:transform:org.apache.beam:schemaio_bigquery_write:v1" payload:"\nX\n\x0e\n\x08location\x1a\x02\x10\x07\n\x0c\n\x06config\x1a\x02\x10\t\n\x12\n\ndataSchema\x1a\x04\x08\x01\x10\t\x12$3fc24beb-ef0b-4fd0-b491-64340b33ca1e\x12a\x03\x01\x04\x00\\\x04\x01\x06Rapache-beam-testing.beam_bigquery_io_test_temp.go_bqio_it_temp_1674894766078736063\x05Never"} inputs:{key:"i0" value:"n2"} environment_id:"go"} namespace:"ODzYEFkVGG"
expansion failed
	caused by:
java.lang.IllegalArgumentException: Triggering frequency or number of file shards can be specified only when writing an unbounded PCollection via FILE_LOADS or STORAGE_API_WRITES, but: the collection was BOUNDED and the method was STORAGE_WRITE_API
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:440)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:2866)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQueryIO$Write.expand(BigQueryIO.java:1932)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:482)
	at org.apache.beam.sdk.values.PCollection.apply(PCollection.java:360)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:227)
	at org.apache.beam.sdk.io.gcp.bigquery.BigQuerySchemaIOProvider$BigQuerySchemaIO$2.expand(BigQuerySchemaIOProvider.java:196)
	at org.apache.beam.sdk.Pipeline.applyInternal(Pipeline.java:548)
	at org.apache.beam.sdk.Pipeline.applyTransform(Pipeline.java:499)
	at org.apache.beam.sdk.expansion.service.ExpansionService$TransformProvider.apply(ExpansionService.java:400)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:526)
	at org.apache.beam.sdk.expansion.service.ExpansionService.expand(ExpansionService.java:606)
	at org.apache.beam.model.expansion.v1.ExpansionServiceGrpc$MethodHandlers.invoke(ExpansionServiceGrpc.java:305)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.stub.ServerCalls$UnaryServerCallHandler$UnaryServerCallListener.onHalfClose(ServerCalls.java:182)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerCallImpl$ServerStreamListenerImpl.halfClosed(ServerCallImpl.java:354)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ServerImpl$JumpToApplicationThreadServerStreamListener$1HalfClosed.runInContext(ServerImpl.java:866)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.ContextRunnable.run(ContextRunnable.java:37)
	at org.apache.beam.vendor.grpc.v1p48p1.io.grpc.internal.SerializingExecutor.run(SerializingExecutor.java:133)
	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:750)


goroutine 50 [running]:
testing.tRunner.func1.2({0xf47b40, 0xc00053a4c0})
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1396 +0x24e
testing.tRunner.func1()
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1399 +0x39f
panic({0xf47b40, 0xc00053a4c0})
	/home/jenkins/sdk/go1.19.3/src/runtime/panic.go:884 +0x212
github.com/apache/beam/sdks/v2/go/pkg/beam.CrossLanguage({0xc000492780?, 0xc0000bc280?}, {0x110f943, 0x39}, {0xc0000f0180?, 0xa969c0?, 0x1?}, {0xc0001297e0, 0xf}, 0xc0001abd20, ...)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/xlang.go>:165 +0x136
github.com/apache/beam/sdks/v2/go/pkg/beam/io/xlang/bigqueryio.Write({0xc000492720?, 0xc0000bc280?}, {0xc00004ccc0, 0x52}, {0x1?}, {0xc0001abea8, 0x2, 0x7f714a3530d0?})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/pkg/beam/io/xlang/bigqueryio/bigquery.go>:252 +0x3d7
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.WritePipeline({0xc0001297e0, 0xf}, {0xc00004ccc0, 0x52}, {0xe96fa0, 0xc0003f6160})
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:126 +0x21f
github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery.TestBigQueryIO_BasicWriteRead(0xc0001036c0)
	<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/integration/io/xlang/bigquery/bigquery_test.go>:216 +0x1ec
testing.tRunner(0xc0001036c0, 0x113eec8)
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1446 +0x10b
created by testing.(*T).Run
	/home/jenkins/sdk/go1.19.3/src/testing/testing.go:1493 +0x35f
FAIL	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/bigquery	7.244s
=== RUN   TestDebeziumIO_BasicRead
    integration.go:308: Test TestDebeziumIO_BasicRead is currently filtered for runner dataflow
--- SKIP: TestDebeziumIO_BasicRead (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/debezium	3.035s
=== RUN   TestJDBCIO_BasicReadWrite
    integration.go:308: Test TestJDBCIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_BasicReadWrite (0.00s)
=== RUN   TestJDBCIO_PostgresReadWrite
    integration.go:308: Test TestJDBCIO_PostgresReadWrite is currently filtered for runner dataflow
--- SKIP: TestJDBCIO_PostgresReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/jdbc	3.029s
=== RUN   TestKafkaIO_BasicReadWrite
    integration.go:308: Test TestKafkaIO_BasicReadWrite is currently filtered for runner dataflow
--- SKIP: TestKafkaIO_BasicReadWrite (0.00s)
PASS
ok  	github.com/apache/beam/sdks/v2/go/test/integration/io/xlang/kafka	6.030s
FAIL
$ TEST_EXIT_CODE=0
$ cd ../..
$ docker rmi us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209
Untagged: us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c3e0b29f1b6a4cad4a8b32d6c2da03c7b226d3ed5a2e9244ae519a9699e39cab
Deleted: sha256:5638b219dfa22a962e664ffe171fbf0288de8dc040299cceca7f4efa451f7bc6
Deleted: sha256:e7a25dc733d00ba148999a8a6891949ad8ede823d42fab66d9a32dcd03f7594b
Deleted: sha256:9a41343c15ca8070f8c204e7d08f11d48083ceaa0d344638b9b9a857dd59fafa
Deleted: sha256:e2b6cb7d1b258837bda83c1a13385e830a330d9e0200d7b2e4075fb90f24d65b
Deleted: sha256:d237207a4511d8e715a21d2df2a8cc4911f74b0f9837dbfb91c3c5ec40c0611a
Deleted: sha256:418d8142cfb521d767adc1abf85bf8e6e456dd023a4f85742f4cfa21f38bdb1f
Deleted: sha256:e1b2e6dfb1f176da082829b4cd7074508a71fdf5c00cae3ffd3365b8d2f2d3d9
Deleted: sha256:0e6615a99fad93825ab9f0fd34073f92184c2d79205fa1f8180a43d2f2ecd48a
Deleted: sha256:f8fa146ebe07b170cb85e9e767c28f08038b5348b30c3491001ad75e8090caa4
Deleted: sha256:2e7bf744f6f00ac59bd672fe8aa13b1e735b03ccc1515cf5e8f01bec65451dc8
Deleted: sha256:3ea47fb948d8ece57f45792361fcee746ac9a2388cfc123e86a09ed1c6032a68
Deleted: sha256:4ca85a5a15ad2583c2e1d973147fd643686f3644cff7a88d57c6eeb717d0ac1a
Deleted: sha256:ecbb8c19d2dc374c0dcc7c93daf909aa4dd7419e3ddcbbce581031b7215d245c
Deleted: sha256:a184b9485447f5e8252a214c4fdc1df13db33fdd1a601bc5494eb31f52952dff
Deleted: sha256:18102ea26164ac278c6951055d31a6534ffbaab0592e51d65e950062c343f482
Deleted: sha256:24855aae739a6356d8b4758a73ffbeb16930162ac251070b22d35998073f2a45
Deleted: sha256:5ba82c15aa2ee5f3515a2e9ef831a63793664328508bb1cdbc36e1d6d8b1516c
$ gcloud --quiet container images delete us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Digests:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c3e0b29f1b6a4cad4a8b32d6c2da03c7b226d3ed5a2e9244ae519a9699e39cab
  Associated tags:
 - 20230128-083209
Tags:
- us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk:20230128-083209].
Deleted [us.gcr.io/apache-beam-testing/jenkins/beam_go_sdk@sha256:c3e0b29f1b6a4cad4a8b32d6c2da03c7b226d3ed5a2e9244ae519a9699e39cab].
$ rm -rf /tmp/tmp.5geORvVKWd
$ exit 1
$ exit 1

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava FAILED
> Task :runners:google-cloud-dataflow-java:cleanupXVR UP-TO-DATE

> Task :runners:google-cloud-dataflow-java:cleanUpDockerPythonImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128082043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/python:20230128082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/python@sha256:80cd875caea0b9f5817e86560e05ae554f063c8d08af9a1be2345319b0849029].

> Task :runners:google-cloud-dataflow-java:cleanUpDockerJavaImages
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128082043
Untagged: us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2
WARNING: Successfully resolved tag to sha256, but it is recommended to use sha256 directly.
Tag: [us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128082043]
- referencing digest: [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2]

Deleted [[us.gcr.io/apache-beam-testing/java-postcommit-it/java:20230128082043] (referencing [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2])].
Removing untagged image us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2
Digests:
- us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2
Deleted [us.gcr.io/apache-beam-testing/java-postcommit-it/java@sha256:83021873c74fac7f2ce616190e0f4f6a3140d20f5991132d0cda647a8f60fcd2].

> Task :runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerCleanup
Stopping expansion service pid: 693964.
Stopping expansion service pid: 693965.

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_XVR_GoUsingJava_Dataflow/ws/src/sdks/go/test/build.gradle'> line: 193

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesCrossLanguageRunnerGoUsingJava'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
> Run with --stacktrace option to get the stack trace.
> Run with --info or --debug option to get more log output.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 8.0.

You can use '--warning-mode all' to show the individual deprecation warnings and determine if they come from your own scripts or plugins.

See https://docs.gradle.org/7.5.1/userguide/command_line_interface.html#sec:command_line_warnings

Execution optimizations have been disabled for 1 invalid unit(s) of work during this build to ensure correctness.
Please consult deprecation warnings for more details.

BUILD FAILED in 1h 7m 18s
216 actionable tasks: 143 executed, 61 from cache, 12 up-to-date

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

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