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

Build failed in Jenkins: beam_PreCommit_Java_Cron #3276

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

Changes:

[MATTHEW.Ouyang] [BEAM-10532] convert NUMERIC field in TableSchema

[srohde] Add record_pipeline and clear to RM and fix duration limiter

[srohde] Add comments to RecordingManager

[Kyle Weaver] [BEAM-10768] Sleep in time-based flush test to ensure correct ordering.

[Kyle Weaver] Move ZetaSQL UDF tests into separate class.

[chamikaramj] Sets sdk_harness_container_images property for all UW jobs

[noreply] Merge pull request #12900 from [BEAM-10941] Use standard sharding

[Kyle Weaver] Move testCreateFunctionNoSelectThrowsException into ZetaSqlUdfTest.

[Kyle Weaver] Add comment explaining flush callbacks.

[noreply] [BEAM-10894] Support for more pandas formats. (#12844)

[noreply] [BEAM-9547] Raise NotImplementedError and WontImplementError throughout

[noreply] [BEAM-4091] Pass type hints in ptransform_fn (#9907)


------------------------------------------
[...truncated 2.70 MB...]
  location: class Watch
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/transforms/Watch.java>:173: error: cannot find symbol
      extends PTransform<PCollection<InputT>, PCollection<KV<InputT, OutputT>>> {
                                              ^
  symbol:   class PCollection
  location: class Watch
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/transforms/Watch.java>:173: error: cannot find symbol
      extends PTransform<PCollection<InputT>, PCollection<KV<InputT, OutputT>>> {
                                                          ^
  symbol:   class KV
  location: class Watch
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:633: error: cannot find symbol
  static class ConvertCoGbkResult extends DoFn<KV<Row, CoGbkResult>, Row> {
                                          ^
  symbol:   class DoFn
  location: class CoGroup
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:633: error: cannot find symbol
  static class ConvertCoGbkResult extends DoFn<KV<Row, CoGbkResult>, Row> {
                                               ^
  symbol:   class KV
  location: class CoGroup
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:633: error: cannot find symbol
  static class ConvertCoGbkResult extends DoFn<KV<Row, CoGbkResult>, Row> {
                                                  ^
  symbol:   class Row
  location: class CoGroup
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:633: error: cannot find symbol
  static class ConvertCoGbkResult extends DoFn<KV<Row, CoGbkResult>, Row> {
                                                       ^
  symbol:   class CoGbkResult
  location: class CoGroup
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:633: error: cannot find symbol
  static class ConvertCoGbkResult extends DoFn<KV<Row, CoGbkResult>, Row> {
                                                                     ^
  symbol:   class Row
  location: class CoGroup
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:658: error: cannot find symbol
        @Element KV<Row, CoGbkResult> element, ProcessContext c, OutputReceiver<Row> o) {
                                               ^
  symbol:   class ProcessContext
  location: class ConvertCoGbkResult

> Task :sdks:java:extensions:protobuf:checkstyleTest
> Task :sdks:java:extensions:google-cloud-platform-core:test
> Task :sdks:java:extensions:google-cloud-platform-core:check
> Task :sdks:java:extensions:google-cloud-platform-core:build
> Task :sdks:java:io:elasticsearch:assemble
> Task :sdks:java:io:elasticsearch:analyzeClassesDependencies SKIPPED
> Task :sdks:java:io:elasticsearch:compileTestJava NO-SOURCE
> Task :sdks:java:io:elasticsearch:testClasses UP-TO-DATE
> Task :sdks:java:io:elasticsearch:analyzeTestClassesDependencies SKIPPED
> Task :sdks:java:io:elasticsearch:analyzeDependencies SKIPPED
> Task :sdks:java:io:elasticsearch:checkstyleMain
> Task :sdks:java:io:elasticsearch:checkstyleTest NO-SOURCE

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:658: error: cannot find symbol
        @Element KV<Row, CoGbkResult> element, ProcessContext c, OutputReceiver<Row> o) {
         ^
  symbol:   class Element
  location: class ConvertCoGbkResult
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/transforms/CoGroup.java>:656: error: cannot find symbol
    @ProcessElement
     ^
  symbol:   class ProcessElement
  location: class ConvertCoGbkResult

> Task :sdks:java:extensions:protobuf:javadoc

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/transforms/CombineFns.java>:118: warning - Tag @link: can't find with(SimpleFunction, CombineFn, TupleTag) in org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/transforms/CombineFns.java>:144: warning - Tag @link: can't find with(SimpleFunction, CombineFnWithContext, TupleTag) in org.apache.beam.sdk.transforms.CombineFns.ComposeCombineFnBuilder

> Task :sdks:java:io:elasticsearch:javadoc
> Task :sdks:java:extensions:protobuf:spotbugsTest SKIPPED

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:329: warning - Tag @link: can't find continuously(Duration, TerminationCondition) in org.apache.beam.sdk.io.FileIO.Match
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1010: warning - Tag @link: can't find watchForNewFiles in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1004: warning - Tag @link: can't find withEmptyMatchTreatment in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1022: warning - Tag @link: can't find withHintMatchesManyFiles() in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1190: warning - Tag @link: can't find watchForNewFiles in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1184: warning - Tag @link: can't find withEmptyMatchTreatment in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:878: warning - Tag @link: can't find watchForNewFiles in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:872: warning - Tag @link: can't find withEmptyMatchTreatment in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1350: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.AvroIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1350: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.AvroIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1327: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.AvroIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/AvroIO.java>:1658: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.AvroIO.TypedWrite

> Task :sdks:java:fn-execution:test
> Task :sdks:java:fn-execution:check
> Task :sdks:java:fn-execution:build
> Task :sdks:java:extensions:protobuf:spotbugsMain
> Task :sdks:java:io:elasticsearch:spotbugsTest SKIPPED
> Task :sdks:java:io:elasticsearch:test NO-SOURCE
> Task :sdks:java:io:hadoop-common:assemble
> Task :sdks:java:io:hadoop-common:analyzeClassesDependencies SKIPPED

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/DynamicFileDestinations.java>:134: warning - Tag @link: can't find constant(FilenamePolicy, SerializableFunction) in org.apache.beam.sdk.io.DynamicFileDestinations
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/FileBasedSource.java>:204: warning - Tag @link: can't find FileBasedSource(Metadata, long, long, long) in org.apache.beam.sdk.io.FileBasedSource
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/FileIO.java>:311: warning - Tag @link: can't find withNaming(Write.FileNaming) in org.apache.beam.sdk.io.FileIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/FileIO.java>:311: warning - Tag @link: can't find via(Contextful, Sink) in org.apache.beam.sdk.io.FileIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/FileIO.java>:331: warning - Tag @link: can't find continuously(Duration,
 TerminationCondition) in org.apache.beam.sdk.io.FileIO.MatchAll
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find continuously(Duration, TerminationCondition) in org.apache.beam.sdk.io.FileIO.Match
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:257: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:498: warning - Tag @link: can't find watchForNewFiles(Duration, TerminationCondition) in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:492: warning - Tag @link: can't find withEmptyMatchTreatment in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:559: warning - Tag @link: can't find withDelimiter in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:719: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:793: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:819: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:819: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:831: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:831: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1092: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1079: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1105: warning - Tag @link: can't find to(SerializableFunction, Params) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1193: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1193: warning - Tag @link: can't find to(SerializableFunction, Params) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1161: warning - Tag @link: can't find withWritableByteChannelFactory(WritableByteChannelFactory) in org.apache.beam.sdk.io.TextIO.TypedWrite

> Task :sdks:java:io:hadoop-common:compileTestJava
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.

> Task :sdks:java:io:hadoop-common:testClasses
> Task :sdks:java:io:hadoop-common:analyzeTestClassesDependencies SKIPPED
> Task :sdks:java:io:hadoop-common:analyzeDependencies SKIPPED
> Task :sdks:java:io:azure:test
> Task :sdks:java:io:azure:check
> Task :sdks:java:io:azure:build
> Task :sdks:java:io:azure:buildDependents
> Task :model:job-management:buildNeeded
> Task :sdks:java:io:hadoop-common:checkstyleMain
> Task :sdks:java:io:elasticsearch:spotbugsMain
> Task :sdks:java:io:elasticsearch:check
> Task :sdks:java:io:elasticsearch:build
> Task :sdks:java:io:hadoop-common:checkstyleTest

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/values/PCollection.java>:301: warning - Tag @link:illegal character: "60" in "PCollection<Row>"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/values/PCollection.java>:301: warning - Tag @link:illegal character: "62" in "PCollection<Row>"

> Task :sdks:java:extensions:sql:hcatalog:compileJava
> Task :sdks:java:extensions:sql:hcatalog:classes
> Task :sdks:java:io:hadoop-common:javadoc

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:288: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:296: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"

> Task :sdks:java:io:hadoop-common:spotbugsMain
> Task :sdks:java:io:hadoop-common:spotbugsTest SKIPPED
> Task :sdks:java:extensions:sql:hcatalog:javadoc

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:127: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:139: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:84: warning - Tag @see: can't find combining(Coder, CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:102: warning - Tag @see: can't find combining(Coder, CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:113: warning - Tag @link: can't find combining(CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:132: warning - Tag @link: can't find combining(CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs
59 warnings

> Task :sdks:java:extensions:protobuf:test
> Task :sdks:java:extensions:protobuf:check
> Task :sdks:java:extensions:protobuf:build
> Task :sdks:java:io:kinesis:check
> Task :sdks:java:io:kinesis:build
> Task :sdks:java:io:kinesis:buildDependents
> Task :sdks:java:io:common:test
> Task :sdks:java:io:common:check
> Task :sdks:java:io:common:build
> Task :sdks:java:javadoc:allJavadoc
> Task :sdks:java:core:spotbugsTest SKIPPED
> Task :sdks:java:io:hadoop-common:test
> Task :sdks:java:io:hadoop-common:check
> Task :sdks:java:io:hadoop-common:build
> Task :sdks:java:io:hadoop-common:buildDependents
> Task :sdks:java:extensions:sql:jdbc:shadowJarTest
> Task :sdks:java:extensions:sql:jdbc:preCommit
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:buildDependents
> Task :sdks:java:core:spotbugsMain
> Task :sdks:java:core:test
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:buildDependents
> Task :runners:flink:1.11:check
> Task :runners:flink:1.11:build
> Task :runners:flink:1.11:buildDependents
> Task :sdks:java:io:google-cloud-platform:buildDependents
> Task :runners:java-job-service:buildDependents
> Task :sdks:java:testing:test-utils:buildDependents
> Task :sdks:java:extensions:protobuf:buildDependents
> Task :sdks:java:expansion-service:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-common:buildDependents
> Task :runners:direct-java:buildDependents
> Task :sdks:java:io:elasticsearch:buildDependents
> Task :runners:local-java:buildDependents
> Task :runners:java-fn-execution:buildDependents
> Task :sdks:java:io:common:buildDependents
> Task :sdks:java:harness:buildDependents
> Task :vendor:sdks-java-extensions-protobuf:buildDependents
> Task :sdks:java:extensions:google-cloud-platform-core:buildDependents
> Task :runners:core-java:buildDependents
> Task :runners:core-construction-java:buildDependents
> Task :sdks:java:fn-execution:buildDependents
> Task :sdks:java:core:validateShadedJarDoesntLeakNonProjectClasses
> Task :sdks:java:core:check
> Task :sdks:java:core:build
> Task :sdks:java:core:buildDependents
> Task :sdks:java:core:buildNeeded

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:direct-java:needsRunnerTests'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/direct-java/build/reports/tests/needsRunnerTests/index.html>

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.6.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 30m 43s
981 actionable tasks: 912 executed, 67 from cache, 2 up-to-date

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

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

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


Jenkins build is back to normal : beam_PreCommit_Java_Cron #3279

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


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


Build failed in Jenkins: beam_PreCommit_Java_Cron #3278

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

Changes:


------------------------------------------
[...truncated 2.68 MB...]
> Task :sdks:java:io:elasticsearch:check
> Task :sdks:java:io:elasticsearch:build
> Task :sdks:java:io:hadoop-common:javadoc
> Task :sdks:java:extensions:protobuf:test
> Task :sdks:java:extensions:protobuf:check
> Task :sdks:java:extensions:protobuf:build
> Task :sdks:java:extensions:sql:hcatalog:compileJava
> Task :sdks:java:extensions:sql:hcatalog:classes
> Task :sdks:java:io:hadoop-common:spotbugsTest SKIPPED
> Task :sdks:java:io:common:test
> Task :sdks:java:io:common:check
> Task :sdks:java:io:common:build
> Task :sdks:java:io:hadoop-common:spotbugsMain

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:288: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:296: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:127: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:139: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides

> Task :sdks:java:harness:check
> Task :sdks:java:harness:build
> Task :sdks:java:extensions:sql:hcatalog:javadoc

> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:84: warning - Tag @see: can't find combining(Coder, CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:102: warning - Tag @see: can't find combining(Coder, CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:113: warning - Tag @link: can't find combining(CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:132: warning - Tag @link: can't find combining(CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs

> Task :sdks:java:io:hadoop-common:test
> Task :sdks:java:io:hadoop-common:check
> Task :sdks:java:io:hadoop-common:build
> Task :sdks:java:io:hadoop-common:buildDependents
> Task :sdks:java:javadoc:allJavadoc
> Task :sdks:java:core:spotbugsTest SKIPPED
> Task :sdks:java:extensions:sql:jdbc:shadowJarTest
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:buildDependents
> Task :sdks:java:core:spotbugsMain
> Task :sdks:java:core:test
> Task :sdks:java:extensions:sql:jdbc:preCommit
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:buildDependents

> Task :runners:flink:1.11:test
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d0a37645-09a6-463c-b7e0-ee1a572e4bb5
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d36f0665-115a-464f-b0bd-fd34a63bb04c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a8552738-ec2e-44d4-85f9-525ec1e156bd
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-06a7f7c1-d5a6-4180-98e3-a92d041ada53
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cef785db-bde4-40ef-996c-a6ddf3eaf507
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ed6784d8-2c76-4948-b9f6-5896f09503f6
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-30be917a-d3d1-4e1e-ae25-8b34e2b56341
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-339ed45f-e3f9-47b8-bc57-a04a14ed493c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2d9f271e-6ca7-40a9-8f6f-523b4fb4816b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e4225044-0bb4-4ebc-bf12-e40c74f74561
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e8fa94f7-a121-44c4-a0bc-4a66a6142851
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fc2fc1f4-989c-46ce-b455-ef8ceff85c8a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1bc7e086-194c-4021-9bb7-5da8cd58ddbc
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ad4a4321-b1ab-4d0c-9443-24746a11029e
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b755cbed-ba35-4c40-9727-f54b2ebaae42
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-95cbc787-4280-4152-a05e-57b533d7efb1
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-58a7c7e2-68e0-42d5-b5a8-25e18a372742
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f471600a-2d1a-40cb-bbd8-1e39b9aba860
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d7bb304b-5300-4791-81e8-df72accf9523
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d29956ff-52e9-4b47-9182-43e10086e79c
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c11d296d-9f2d-4906-8716-aa07580bc3da
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-129040c7-9c1d-4e11-87ad-d26bccdc1c30
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-abbb6ec6-13c3-4c71-8e93-0d501f759989
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-945b3485-2cbb-4cba-8be0-caeb3d4b12a1
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e7876aea-644f-407e-9342-e7ab287886f3
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-29d4dbf4-732a-444e-9170-e49b55fd82cb
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-316a8bd3-b3d8-448f-80ca-15ed7df4dfc6
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-068e0111-343b-47e9-9216-a7be8a45d1b4
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b13ac075-d9a7-4343-ad8c-64dedc9e69c5
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d318c43d-01c2-4344-9503-6c9bb8dbf643
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-326befd8-8bab-43ec-aff4-30c7e84c1fe7
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f8f3e847-97ac-495a-8cd7-e18f37529e6a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4b7a0783-d56f-4f78-9cbf-297419cc35ca
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f3db9647-db68-432d-9821-fa868a160ef2
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-204c856d-1073-4f01-bf5f-de2f6179a9fd
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-852a620c-2351-4426-9240-38483db7854a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-24381b38-423b-46ea-97d2-76b96e86339a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a5cd2c3f-c724-4be8-b7b6-c8960e9d8596
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-55fe6c7b-b190-4e90-88b8-4f550fa36645
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e9cce1f9-67db-425f-83ea-19dacf8b1252
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-38c59b10-de35-4407-991b-6ab7e9eaa99a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2f4af31c-d019-40fa-92d0-1f9b6ca9a3ec
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a35e303c-c1e1-4650-88f5-75ee1683a8c9
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-68a99bdb-9f5e-4e45-bea9-2ca97b70ec23
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7e62f839-6b54-4c1d-b616-248da4ab61c4
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-95e7811f-5ce7-4bed-b414-dc37636491c2
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b8c4f688-a9ec-4a3c-ae3d-49c73a24210e
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9bef395f-4a09-491e-ada2-f74145e048f4
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e7487e79-df6c-405a-a3c9-b266577275fd
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-6999b966-0dd6-45aa-ae7a-c75bb1938c06
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-94ea3a55-f87e-4d6b-bbb7-5a6c0e584628
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-6d1c7d05-a7dd-49ad-af86-fdb83e621d1c
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9badbc4a-fbe5-4c81-b36e-8761bc33ef5a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7c39e05b-0a9a-48d4-a043-b18199ec7306
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-6b5116dc-8879-41fc-a751-8feffbe89932
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-568250a3-e7ba-402c-bc00-9e2c8885fa2e
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-225fb157-1799-4c7d-b58c-45c5db41fd90
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a0feb344-beb2-4ecd-8048-42a0b2759541
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-13175bc3-318e-4901-8e7c-934105b7cc3e
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-27a2a3bb-9a91-4317-ad7b-b1bb1e80e5e3
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8ad090c6-2657-44bb-8f1e-f023c7e03a85
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4ea9b517-7536-4ea3-94a2-697671177f87
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-677f9133-1c7c-4ac0-91e6-a8df8d8a083d
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-83efd8e6-e3ef-4277-af71-0753d7c31bdd
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2522f5ca-90ca-4a43-90e4-eb9673b7c3cc
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8f22fa3c-36ca-4403-915c-8c13e6ee3570
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-24111505-2279-407d-8a7c-ca92daa31d3f
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-eda98e79-ce4b-4117-a393-5e68fb8d5cb9
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-178a73ab-74d8-4215-b729-820501cdf0e5
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4081f519-ab59-4ac8-8be4-3e6350367bb3
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9d53bdee-8a83-407c-8efa-a17d0df15aac
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ef66a9f4-2cd0-4435-a4e2-ec2134f959ef
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e56fd65d-bca3-4d6a-8f5d-566c03d59bc9
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-20946b82-c40d-48b0-a62d-5e298f9cf685
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e5c63c70-2e17-4cfe-8e41-75ffd0bd028b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e7f9b854-6071-4624-802d-c0b78f18fd0a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1f4ff4f8-0a6b-410d-81bb-ae725dc0b9a0
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c90d16a3-20b7-475c-aa55-7f75c0111eb8
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-beafad5a-ead3-4f30-b5c4-afd28f3e0df9
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e322c711-4e00-4bf4-87e2-f3c1626a76df
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d599c2e2-d013-40d4-90b3-8259a9026190
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-506f60c8-f41a-46aa-b544-cb96331e3940
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e51be04a-c549-438c-b01b-fd4a7248519a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b7e8c846-fa3d-4d53-8191-02ff7746b830
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-54565fa6-666d-46ab-bc28-9e76f14d8ba5
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-5f8d2252-d9a7-446b-9a32-57c06ba99233
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a29ba157-2300-423f-a194-b7dffbee8d5f
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9d252d59-6c6a-4a62-852e-8df2c50e40ab
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-81551239-976c-4429-9295-9c6a48db8e42
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2c5a00f3-7d5f-4604-ad62-5f3b25311ed7
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4ccd57c0-a4ab-4389-88fb-10a660cfe928
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-25892a34-ceec-4b18-800a-a3507da90b7a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f60350b6-b35a-43a8-b86f-b76c6ce9f624
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-69193d49-e31c-497a-b82d-ef6c3cfc7d4c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-04ac2546-7395-4ad6-935a-e10f2a75a618

> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-common:buildDependents
> Task :sdks:java:io:elasticsearch:buildDependents

> Task :runners:flink:1.11:test
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d468b6dc-bd2a-43ad-bce6-6c709cf4f92f
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cf6619b1-d2bd-4a4c-9d97-f194f379fd31
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-afaafefa-3ad3-4792-a462-b0940df6be37
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9ed6bf29-f125-4ee4-ae79-294de0d8e509
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c3e860c9-a86d-479d-a9c6-d65458a87775
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1fc1dd35-6ee4-4ec2-9408-cd13f23c8ba6
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-26319c21-790f-4942-943e-8f0b380967aa
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7a88dc8a-0c83-48f1-ade9-d115ee360d63
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9a8c8eaf-d791-4e6d-862c-4eb8968564a1
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-53598c56-f003-41ca-8398-f0a5950111c2
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-41234016-4b05-4c13-a8a5-60b1b6eb4624
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1ee09a2f-5486-4f5d-96d3-09fb3a966f65
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-3df73dbc-6d77-4053-b49d-f413a67f2a3f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-988cd139-63f0-474a-a835-9024156b4f95
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-5ee49cdf-edf0-472a-a617-b0dff9e1bddf
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-0b33d865-bf9b-491b-a5a0-49491594487a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-6c6cc0d2-e41c-4eb7-878a-eb77be18d2c4
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-40169b37-c982-4dc5-a0a0-60b3d05ab128
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8ad65628-d452-41e0-aed7-e3358197d0e8
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fa27bb76-7e4b-4656-9c18-81619cb532f7
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-59062bf3-931e-406a-98ad-1f32a5341197
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e4b7653a-3197-41a3-b304-0991d6ed3410
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fbe658e8-e346-4428-a075-23c0bff79ed5
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b6234c17-e542-457d-9e26-e9939dd9885b
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-13e826b6-6b67-4dd6-9383-51eb187bdefa
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-db335515-0a5c-4fd6-8887-0d0ef382e1da
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-631e9bd9-6683-46aa-845e-edc58c2e9ea0
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-306ef6f6-747a-4298-803c-265ad6c65224
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f1f7a53d-bb7f-469a-898f-ea0a0440fd6a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-56e4933f-8698-4094-b429-b7f218e57b04
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-78fd6895-8942-4329-8980-beab9368e293
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-6c13b9f0-f7cc-4a99-8711-30026699e4e8
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f2b178d4-e8e9-49d9-b09a-0f6835ebd1d3
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-3514888c-25ed-4334-8b24-0d9419ffa1ea
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9ddebf65-3284-47fe-b997-81bb76425106
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8fdbb92b-04a4-4adb-859f-d8e500bd6373
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-70af932d-1360-4194-b81d-8649ee60b745
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-20e5402d-be67-4620-8e5e-a05dbae4dd5a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-96e0c387-0146-4368-ad59-bfec32079802
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7ffe14c4-b428-4147-b490-c0cd01ffae7b
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cce9d8ac-1378-49d7-ade9-f47742a82fdc
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b7f972c6-4a11-49b6-aaac-1fde001b22e1
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1b7e972d-0f61-4c42-a0ed-fc4272572e72
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ee1b8068-eb46-456c-b419-3c427a381f75
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cc98f16c-0cb1-4881-ac51-b7acca724075
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e4ac3e36-b81e-4ca7-b358-551353b39aae
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fa60b90b-2769-4d2c-8ea1-37fa7e35272e

> Task :runners:flink:1.11:check
> Task :runners:flink:1.11:build
> Task :runners:flink:1.11:buildDependents
> Task :sdks:java:io:google-cloud-platform:buildDependents
> Task :runners:java-job-service:buildDependents
> Task :sdks:java:testing:test-utils:buildDependents
> Task :sdks:java:extensions:protobuf:buildDependents
> Task :sdks:java:io:common:buildDependents
> Task :runners:direct-java:buildDependents
> Task :sdks:java:expansion-service:buildDependents
> Task :runners:local-java:buildDependents
> Task :runners:java-fn-execution:buildDependents
> Task :sdks:java:harness:buildDependents
> Task :vendor:sdks-java-extensions-protobuf:buildDependents
> Task :runners:core-java:buildDependents
> Task :sdks:java:extensions:google-cloud-platform-core:buildDependents
> Task :runners:core-construction-java:buildDependents
> Task :sdks:java:fn-execution:buildDependents
> Task :sdks:java:core:validateShadedJarDoesntLeakNonProjectClasses
> Task :sdks:java:core:check
> Task :sdks:java:core:build
> Task :sdks:java:core:buildDependents
> Task :sdks:java:core:buildNeeded

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:direct-java:needsRunnerTests'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/direct-java/build/reports/tests/needsRunnerTests/index.html>

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.6.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 30m 55s
981 actionable tasks: 900 executed, 79 from cache, 2 up-to-date

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

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_PreCommit_Java_Cron #3277

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

Changes:

[noreply] [BEAM-10716] TestPubsub/TestPubsubSignal clean up subscriptions (#12830)

[noreply] Revert "[BEAM-9547] Raise NotImplementedError and WontImplementError

[noreply] [BEAM-7372] Drop Python 2 shims and update docstring in

[noreply] [BEAM-10769] Clarify Avro IO documentation. (#12638)

[noreply] [BEAM-10814][BEAM-10570] DataframeTransform outputs elements (#12882)

[noreply] [BEAM-10871] Fix FhirLROIT tests (again) (#12908)


------------------------------------------
[...truncated 2.66 MB...]
> Task :sdks:java:core:javadoc
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find continuously(Duration, TerminationCondition) in org.apache.beam.sdk.io.FileIO.Match
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:182: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:257: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:498: warning - Tag @link: can't find watchForNewFiles(Duration, TerminationCondition) in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:492: warning - Tag @link: can't find withEmptyMatchTreatment in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:559: warning - Tag @link: can't find withDelimiter in org.apache.beam.sdk.io.Read
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:719: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:793: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:819: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:819: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:831: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:831: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1092: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1079: warning - Tag @link: can't find to(FilenamePolicy) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1105: warning - Tag @link: can't find to(SerializableFunction, Params) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1193: warning - Tag @link: can't find to(DynamicDestinations) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1193: warning - Tag @link: can't find to(SerializableFunction, Params) in org.apache.beam.sdk.io.TextIO.Write
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/io/TextIO.java>:1161: warning - Tag @link: can't find withWritableByteChannelFactory(WritableByteChannelFactory) in org.apache.beam.sdk.io.TextIO.TypedWrite
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/values/PCollection.java>:301: warning - Tag @link:illegal character: "60" in "PCollection<Row>"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/values/PCollection.java>:301: warning - Tag @link:illegal character: "62" in "PCollection<Row>"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:288: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/schemas/SchemaRegistry.java>:296: warning - Tag @link:illegal character: "42" in "* NoSuchSchemaException"
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:127: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/options/SdkHarnessOptions.java>:139: warning - Tag @link: can't find addOverrideForName(String, LogLevel) in org.apache.beam.sdk.options.SdkHarnessOptions.SdkHarnessLogLevelOverrides
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:84: warning - Tag @see: can't find combining(Coder, CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:102: warning - Tag @see: can't find combining(Coder, CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:113: warning - Tag @link: can't find combining(CombineFn) in org.apache.beam.sdk.state.StateSpecs
<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/sdks/java/core/src/main/java/org/apache/beam/sdk/state/StateSpecs.java>:132: warning - Tag @link: can't find combining(CombineFnWithContext) in org.apache.beam.sdk.state.StateSpecs

> Task :sdks:java:javadoc:allJavadoc
> Task :sdks:java:core:spotbugsMain FROM-CACHE
> Task :sdks:java:core:spotbugsTest SKIPPED
> Task :sdks:java:io:kinesis:check
> Task :sdks:java:io:kinesis:build
> Task :sdks:java:io:kinesis:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-2:buildDependents
> Task :sdks:java:io:common:test
> Task :sdks:java:io:common:check
> Task :sdks:java:io:common:build
> Task :sdks:java:extensions:sql:jdbc:shadowJarTest
> Task :sdks:java:extensions:sql:jdbc:preCommit
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-6:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-5:buildDependents
> Task :sdks:java:core:test
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:check
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:build
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-7:buildDependents
> Task :sdks:java:io:elasticsearch-tests:elasticsearch-tests-common:buildDependents
> Task :sdks:java:io:elasticsearch:buildDependents

> Task :runners:flink:1.11:test
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c67cbff0-2bb2-4f1f-854b-37461e367cd5
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ac06cee0-4c7a-4868-92b7-a25dbe9e1df6
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b6670315-f3a0-4fd3-878a-ec498460ab0b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-23d8c8bf-005c-4616-a97f-e58f519669ca
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8a581644-f991-427e-afb5-30c86b3c2e47
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e3826a52-37d5-45d8-9c81-bc60c5a4e226
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7658969d-bf5e-482d-8880-64e84f42012a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-82e8885a-aa5d-4ad2-b8fd-80e514fcc242
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-00e4b7be-537b-4457-8ec0-1e3cdeac5aff
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7de9ce3f-4c66-4130-9ee5-f811fea91f6d
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d3b0daad-2c15-48e9-8303-ca93aa6f3a63
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-75913ad2-f342-4c72-ac71-58770ac31648
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cde406bf-7b9c-4940-aefc-0f28514f85f0
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e71c2111-1d1c-40f8-bcf1-d7318e2bf5c7
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ad7cf1d7-b397-4dd5-a3e9-f14975d8c4f4
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f98d6df7-8060-4b1a-872b-c24cf6ff0801
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7b74eb07-d7d5-4047-96b0-14f7294843e1
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d9377854-f728-4c53-b05f-c68d82decb59
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fd8ab92e-7ebc-47ee-b2b7-0c62c8759210
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fc84d782-eea9-41ae-a0a8-79b3352bb2bb
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-74ab0c89-255e-4227-a692-bffca184274b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-03ad1726-50f7-4d41-ad5a-8a4dff424ef8
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f16f741a-d3b6-4bf7-8368-0319f1028bf8
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4be9a2d0-3125-41d9-8b4d-b99738245b84
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-16980341-2589-432c-bffb-eba1de3e9f81
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-88691957-3b6b-4f99-b43e-52fb8427141d
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2ea470a9-d314-4865-81b0-1e7e53a7015a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-524c793e-0040-4731-942f-47501b259fe8
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4118aef0-9529-46f4-95bd-fbd4403f6ca7
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e73ec834-6fb1-41b6-abe3-46dce961d5a1
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a74c75b7-ac05-410e-a0d6-e895f21c52b2
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-30297e32-f68a-4fbd-8058-d7dac22cfc58
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d7c88218-9c83-4128-8f2d-e72e4207446d
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7f1d106a-ee62-46b6-9f4a-cae98ec7ffbc
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-40ccf47b-ad1f-476d-86bd-9e18622d5944
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-55b53127-4385-4410-ae00-7e40c820fcbf
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-be92c126-9ada-4d65-be02-4f9735fff671
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-239fbf91-ba33-4af5-98c0-200ebc91b6b0
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b71e34c0-bc61-4e81-a595-1a5c0ff4ba85
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b0b7b485-ec66-422b-a20e-b0736da984ac
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8e5f4a2c-8c1c-49e3-a9c0-aa3b1dbc035d
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-da42a30d-cf7b-4921-a3e2-d4c86a1331d9
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-36f9c2a5-76b3-426e-8821-e2123851d484
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2480fdf6-8df1-4a36-b50d-dc4c3b57a544
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-464d22d6-c047-41a0-bbff-c5d0b0ba5127
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-455d530f-ea09-4789-8cb2-bd54e12be05a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-64eedd00-6680-4b57-a45c-79f016bb287e
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-08e36dae-a97f-4969-8795-2f490c158cdf
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7ceca898-4506-4be1-8544-393eb090192b
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-90e5aabf-8358-4da5-bc7f-e9d22871a42d
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2bd6a048-e7a6-4a19-b709-804d7f011321
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-345d0978-8068-4937-9b0e-c5c18f67dae3
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-deb2c7f9-b20a-4e96-84d4-f811ad952b4d
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-12000ab1-9363-4047-96e1-12468905dc37
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-45ab5b72-e7a9-4781-90ed-2a7ecf405efd
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-079207b5-d93c-4cbf-a96d-0641a4223621
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-3553591d-5202-4952-97cc-e886920f0a91
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-16ccfd8d-15b4-4f9d-8e7f-5f6823b323f0
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4075e723-f790-4655-8d6d-1159a3d44fba
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4fc2068b-4f02-4252-ae0d-8db52fc7837f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c26bcf39-2213-4b51-a230-e07ef0a17db3
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8c517f42-9ea1-475f-946c-05cb19e62241
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-76cf8dce-0aed-4ba1-8ed0-7fbf7e556abd
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-55400212-05fb-4f09-a14d-1c56042decab
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ef56a099-cea5-4f74-b60e-e214215e67ac
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ea3f6bee-d5cd-46e3-b6b6-16463dad4a5b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c64ccefc-bbc2-416a-bd87-cdd62f986fe9
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-259ab1f4-32c7-41a0-a4d8-5c627540c306
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ad26631a-ca3d-462e-912d-cb62d1bd3185
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1a6d6360-1885-46bd-8341-237ba1a21894
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-768eb156-2d00-4210-ad06-e94b933ea9f2
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-0eb0683c-b067-4f69-b59b-40bbc8702a0a
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b06e52bc-55d7-4d7e-8073-d4f9f9a3a664
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-db45a5c2-d8e6-455a-9039-71ce8cf8ff55
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-21a319ce-cb2d-4977-90d5-d88356858f6b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-739fef7c-8c94-49f0-af44-b075d3498cc0
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-04929cdc-6dd1-430d-8cd0-bf762fe38b34
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-30190cb7-f4c1-4222-a872-d8c0f98e37ba
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-203e9df5-5b0f-4084-8e66-1f379e646b2a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-066ae374-3e3c-4500-90e3-5c073efd8581
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-0ee4134c-b811-46b6-90e6-7ce7c4df8de4
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f3f63793-5e33-4b91-a99e-5a5984b37b4f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2b05e719-7cb3-44fb-9d76-4daa5abef5d2
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4769506a-418b-4155-8a43-c1adcc5a820f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8faf2166-0a9d-45f6-a784-0db97944d944
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c459ba30-bafb-4301-8af3-3849a1937151
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9cf3534f-bde8-4a24-ad52-4df29a91d968
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ce5a4a6d-a835-4d0b-8114-c9691011d17f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-3f3b1f72-210d-4247-bfb0-6dbb03d4f906
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2daccbd2-cb75-42b1-a723-5b68bd95e2c3
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b47908cd-35ef-45d7-9667-e3b8438d9c9b
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-47297d06-b779-459d-b539-103673efcf8b
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-446c8729-4946-4e77-b885-1f312de8fad0
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b8c4c37d-80b7-4046-851f-8a5320e7a661
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-25b3b13b-f548-4503-abe5-c58301462fbb
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-cc3fa0a2-cf13-4eab-b4c7-dacc2661189c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2ae10bd2-f487-4867-88c1-224a1bfcd947
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1a3aa2cc-2637-43c4-a593-5a4ce9329ace
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f03186b6-25ec-41e0-9a77-6819a40b9d50
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-25144ec7-6446-43ba-b98d-fb474416e13c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c5ac72ca-f1d9-46db-bbf8-d54aff9f7daf
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d0780b3a-3ac0-447d-8456-55660a827785
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-5f56a273-f337-4fec-9a36-b95694f5c612
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2160ea81-0cf6-4818-a64b-ef06cde2b225
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-de6f93b1-ef03-417c-954c-d1c69622d117
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-afb082a6-1171-4ecf-9abc-7200fdedfc2f
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2f0755ba-f668-4866-ab68-e033eba4f2bb
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1e64bcb5-fc46-4af7-b245-c331ce5341ce
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-00105574-9cee-4036-a8bc-d478148dc94f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-0cfa0b96-48ca-4fea-bb58-04ec2123bf8d
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1cdd210f-b914-42ae-8afb-3c37b1bd1f3c
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-592127d0-1740-40f8-bf74-fac4eadf4af2
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-10eea002-05ca-4d6c-b3ab-c4b808deec2a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-ddbd7324-e9e0-4a1d-a2b1-e3758d52e72f
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-a4180689-d0fd-4045-b017-2b704d5831fc
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-359bdee3-6475-40e7-b1c7-58937a4aa790
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c607d2b8-b0a9-4c38-929d-33f0bfd79e5e
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-bf125cae-0ebb-4b9d-bfec-14a6110c5990
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-79be43e4-31c8-41de-81f8-8365e222148a
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-0c82c4ee-2147-439b-bf7c-6c6186b8b4a7
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-4f65e429-6b5f-4016-997d-ec7894bedfa6
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e55be487-1384-4085-a660-58fbb92cbecc
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9fc3b86d-eca4-46c1-af5a-b2fd64e309fc
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2ac94d49-42bd-4e72-85b7-bda2f8863ff6
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d18cb7ba-2972-4ab8-ad2b-1b6cbddbb474
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-b3da83e1-5571-40b3-a495-23db79ed7dd1
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-1f305d4b-70b1-4737-ab5e-31bdba5a766d
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-aea399c9-5959-481c-8fca-0a63262a33bb
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-497aabe3-cc4d-4cfc-a93a-f6c361413fcd
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-054ba042-fe50-4b8e-a07b-d99372528f49
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-fe45195d-6290-44cb-8068-49afa7b80fff
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-8ba74327-a588-4140-bd35-0657ce2c4d95
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-c1d63f47-00c8-4ebc-b5fb-9b42b9793a70
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e5f7dbde-46a4-4bce-af71-dbb6e3cca933
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-9a6fa0c9-8d36-43e1-9eaf-6d06303ed097
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-87c76b63-b4d6-47d7-8c2c-59d0b23f46e4
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-d0f71562-e071-48e3-b8aa-9102c58e77a2
[FileChannelManagerImpl-io shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-e5b73ff2-3f0b-43f6-accd-17dcff4400e5
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-7e64eb85-f5df-44e9-8120-e555e5d08289
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-2f38ba30-5630-4d61-b180-3815b2f0a9d7
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-f9a6a6cb-8fce-4db9-a810-be002db3674f
[IOManagerAsync shutdown hook] INFO org.apache.flink.runtime.io.disk.FileChannelManagerImpl - FileChannelManager removed spill file directory /tmp/flink-io-af3fb5bf-2106-404c-98da-a015b75d1fa4

> Task :runners:flink:1.11:check
> Task :runners:flink:1.11:build
> Task :runners:flink:1.11:buildDependents
> Task :sdks:java:io:google-cloud-platform:buildDependents
> Task :runners:java-job-service:buildDependents
> Task :sdks:java:testing:test-utils:buildDependents
> Task :sdks:java:expansion-service:buildDependents
> Task :sdks:java:extensions:protobuf:buildDependents
> Task :sdks:java:io:common:buildDependents
> Task :runners:direct-java:buildDependents
> Task :runners:java-fn-execution:buildDependents
> Task :runners:local-java:buildDependents
> Task :sdks:java:harness:buildDependents
> Task :vendor:sdks-java-extensions-protobuf:buildDependents
> Task :runners:core-java:buildDependents
> Task :sdks:java:extensions:google-cloud-platform-core:buildDependents
> Task :runners:core-construction-java:buildDependents
> Task :sdks:java:fn-execution:buildDependents
> Task :sdks:java:core:validateShadedJarDoesntLeakNonProjectClasses
> Task :sdks:java:core:check
> Task :sdks:java:core:build
> Task :sdks:java:core:buildDependents
> Task :sdks:java:core:buildNeeded

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:direct-java:needsRunnerTests'.
> There were failing tests. See the report at: file://<https://ci-beam.apache.org/job/beam_PreCommit_Java_Cron/ws/src/runners/direct-java/build/reports/tests/needsRunnerTests/index.html>

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

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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 7.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/6.6.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 27m 8s
981 actionable tasks: 804 executed, 175 from cache, 2 up-to-date

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

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