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 2021/04/02 00:12:32 UTC

Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4571

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

Changes:

[rohde.samuel] Update Dataflow V1Beta3 to newest version to add the

[rohde.samuel] Add the 'enable_hot_key_logging' PipelineOption and plumb it to the

[lpost] [BEAM-12079] Deterministic coding enforcement causes

[noreply] fix: variables names in test-stream.md

[Udi Meiri] Update dev Dataflow containers to latest version.

[Kyle Weaver] [BEAM-12033] Create ZetaSqlException, which contains a GRPC Status code.

[noreply] Merge pull request #14372 from [BEAM-12014] Add BIGNUMERIC support in


------------------------------------------
[...truncated 76.57 KB...]
        ;;
    --expansion_addr)
        EXPANSION_ADDR="$2"
        shift # past argument
        shift # past value
        ;;
    --jenkins)
        JENKINS=true
        shift # past argument
        ;;
    *)    # unknown option
        echo "Unknown option: $1"
        exit 1
        ;;
esac
done

# Go to the root of the repository
cd $(git rev-parse --show-toplevel)
git rev-parse --show-toplevel

# Verify in the root of the repository
test -d sdks/go/test

# Hacky python script to find a free port. Note there is a small chance the chosen port could
# get taken before being claimed by the job server.
SOCKET_SCRIPT="
import socket
s = socket.socket(socket.AF_INET, socket.SOCK_STREAM)
s.bind(('localhost', 0))
print(s.getsockname()[1])
s.close()
"

# Set up environment based on runner.
if [[ "$RUNNER" == "dataflow" ]]; then
  if [[ -z "$DATAFLOW_WORKER_JAR" ]]; then
    DATAFLOW_WORKER_JAR=$(find $(pwd)/runners/google-cloud-dataflow-java/worker/build/libs/beam-runners-google-cloud-dataflow-java-fn-api-worker-*.jar)
  fi
  echo "Using Dataflow worker jar: $DATAFLOW_WORKER_JAR"

  if [[ -z "$EXPANSION_ADDR" && -n "$EXPANSION_SERVICE_JAR" ]]; then
    EXPANSION_PORT=$(python -c "$SOCKET_SCRIPT")
    EXPANSION_ADDR="localhost:$EXPANSION_PORT"
    echo "No expansion address specified; starting a new expansion server on $EXPANSION_ADDR"
    java -jar $EXPANSION_SERVICE_JAR $EXPANSION_PORT &
    EXPANSION_PID=$!
  fi
elif [[ "$RUNNER" == "flink" || "$RUNNER" == "spark" || "$RUNNER" == "portable" ]]; then
  if [[ -z "$ENDPOINT" ]]; then
    JOB_PORT=$(python -c "$SOCKET_SCRIPT")
    ENDPOINT="localhost:$JOB_PORT"
    echo "No endpoint specified; starting a new $RUNNER job server on $ENDPOINT"
    if [[ "$RUNNER" == "flink" ]]; then
      java \
          -jar $FLINK_JOB_SERVER_JAR \
          --flink-master [local] \
          --job-port $JOB_PORT \
          --expansion-port 0 \
          --artifact-port 0 &
    elif [[ "$RUNNER" == "spark" ]]; then
      java \
          -jar $SPARK_JOB_SERVER_JAR \
          --spark-master-url local \
          --job-port $JOB_PORT \
          --expansion-port 0 \
          --artifact-port 0 &
      ARGS="-p 1" # Spark runner fails if jobs are run concurrently.
    elif [[ "$RUNNER" == "portable" ]]; then
      python \
          -m apache_beam.runners.portability.local_job_service_main \
          --port $JOB_PORT &
    else
      echo "Unknown runner: $RUNNER"
      exit 1;
    fi
    JOBSERVER_PID=$!
  fi

  if [[ -z "$EXPANSION_ADDR" && -n "$EXPANSION_SERVICE_JAR" ]]; then
    EXPANSION_PORT=$(python -c "$SOCKET_SCRIPT")
    EXPANSION_ADDR="localhost:$EXPANSION_PORT"
    echo "No expansion address specified; starting a new expansion server on $EXPANSION_ADDR"
    java -jar $EXPANSION_SERVICE_JAR $EXPANSION_PORT &
    EXPANSION_PID=$!
  fi
fi
python -c "$SOCKET_SCRIPT"
python -c "$SOCKET_SCRIPT"

if [[ "$RUNNER" == "dataflow" ]]; then
  # Verify docker and gcloud commands exist
  command -v docker
  docker -v
  command -v gcloud
  gcloud --version

  # ensure gcloud is version 186 or above
  TMPDIR=$(mktemp -d)
  gcloud_ver=$(gcloud -v | head -1 | awk '{print $4}')
  if [[ "$gcloud_ver" < "186" ]]
  then
    pushd $TMPDIR
    curl https://dl.google.com/dl/cloudsdk/channels/rapid/downloads/google-cloud-sdk-186.0.0-linux-x86_64.tar.gz --output gcloud.tar.gz
    tar xf gcloud.tar.gz
    ./google-cloud-sdk/install.sh --quiet
    . ./google-cloud-sdk/path.bash.inc
    popd
    gcloud components update --quiet || echo 'gcloud components update failed'
    gcloud -v
  fi

  # Build the container
  TAG=$(date +%Y%m%d-%H%M%S)
  CONTAINER=us.gcr.io/$PROJECT/$USER/beam_go_sdk
  echo "Using container $CONTAINER"
  ./gradlew :sdks:go:container:docker -Pdocker-repository-root=us.gcr.io/$PROJECT/$USER -Pdocker-tag=$TAG

  # Verify it exists
  docker images | grep $TAG

  # Push the container
  gcloud docker -- push $CONTAINER
else
  TAG=dev
  ./gradlew :sdks:go:container:docker -Pdocker-tag=$TAG
  CONTAINER=apache/beam_go_sdk
fi
Apr 02, 2021 12:11:33 AM org.apache.beam.sdk.expansion.service.ExpansionService loadRegisteredTransforms
INFO: Registering external transforms: [beam:transforms:xlang:test:cgbk, beam:transforms:xlang:test:flatten, beam:transforms:xlang:test:prefix, beam:transforms:xlang:test:multi, beam:transforms:xlang:test:gbk, beam:transforms:xlang:test:comgl, beam:transforms:xlang:test:compk, beam:transforms:xlang:count, beam:transforms:xlang:filter_less_than_eq, beam:transforms:xlang:test:partition, beam:transforms:xlang:test:parquet_write, beam:transforms:xlang:parquet_read, beam:transforms:xlang:textio_read, beam:external:java:generate_sequence:v1]
Apr 02, 2021 12:11:33 AM org.apache.beam.runners.jobsubmission.JobServerDriver createArtifactStagingService
INFO: ArtifactStagingService started on localhost:32849
Apr 02, 2021 12:11:33 AM org.apache.beam.runners.jobsubmission.JobServerDriver createExpansionService
INFO: Java ExpansionService started on localhost:46239
Apr 02, 2021 12:11:33 AM org.apache.beam.runners.jobsubmission.JobServerDriver createJobServer
INFO: JobService started on localhost:35981
Apr 02, 2021 12:11:33 AM org.apache.beam.runners.jobsubmission.JobServerDriver run
INFO: Job server now running, terminate with Ctrl+C

ARGS="$ARGS --timeout=$TIMEOUT"
ARGS="$ARGS --runner=$RUNNER"
ARGS="$ARGS --project=$DATAFLOW_PROJECT"
ARGS="$ARGS --region=$REGION"
ARGS="$ARGS --environment_type=DOCKER"
ARGS="$ARGS --environment_config=$CONTAINER:$TAG"
ARGS="$ARGS --staging_location=$GCS_LOCATION/staging-validatesrunner-test"
ARGS="$ARGS --temp_location=$GCS_LOCATION/temp-validatesrunner-test"
ARGS="$ARGS --dataflow_worker_jar=$DATAFLOW_WORKER_JAR"
ARGS="$ARGS --endpoint=$ENDPOINT"
if [[ -n "$EXPANSION_ADDR" ]]; then
  ARGS="$ARGS --expansion_addr=$EXPANSION_ADDR"
fi

# Running "go test" requires some additional setup on Jenkins.
if [[ "$JENKINS" == true ]]; then
  # Copy the go repo as it is on Jenkins, to ensure we compile with the code
  # being tested.
  cd ..
  mkdir -p temp_gopath/src/github.com/apache/beam/sdks
  cp -a ./src/sdks/go ./temp_gopath/src/github.com/apache/beam/sdks
  TEMP_GOPATH=$(pwd)/temp_gopath
  cd ./src

  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  GOPATH=$TEMP_GOPATH go test -v github.com/apache/beam/sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
else
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  go test -v ./sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
fi
sdks/go/test/integration/integration.go:41:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/ptest" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOPATH)
sdks/go/test/integration/driver/driver.go:26:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOPATH)
sdks/go/test/integration/driver/driver.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOPATH)
sdks/go/test/integration/driver/driver.go:28:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/log" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOPATH)
sdks/go/test/integration/driver/driver.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/x/beamx" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOPATH)
sdks/go/test/integration/driver/driver.go:30:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/primitives" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOPATH)
sdks/go/test/integration/driver/driver.go:31:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOPATH)
sdks/go/test/integration/driver/driver.go:32:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/wordcount" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOPATH)
sdks/go/test/integration/primitives/cogbk.go:22:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/passert" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOPATH)
sdks/go/test/integration/synthetic/synthetic.go:21:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/textio" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/transforms/stats" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOPATH)

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 12m 0s
139 actionable tasks: 101 executed, 36 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

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_PostCommit_Go_VR_Flink #4592

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


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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4591

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

Changes:

[noreply] [BEAM-7372] Remove dead py<3.6 paths (#14436)


------------------------------------------
[...truncated 1.50 MB...]
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.30.0.dev"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:timer:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:row:v1"
      capabilities: "beam:coder:param_windowed_value:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:sharded_key:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.30.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-iX5usnMhooWFVsDnq3d6iP0jxH1RLWWxipZhY6Hvsnw.jar\022@897e6eb27321a2858556c0e7ab777a88fd23c47d512d65b18a966163a1efb27c"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-iX5usnMhooWFVsDnq3d6iP0jxH1RLWWxipZhY6Hvsnw.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-vLiJE9Opd23Iykd81sLP70H_7nOeFCEONM7N3XuinBg.jar\022@bcb88913d3a9776dc8ca477cd6c2cfef41ffee739e14210e34cecddd7ba29c18"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-vLiJE9Opd23Iykd81sLP70H_7nOeFCEONM7N3XuinBg.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-eAT2q5pJyQK8p1x9W86L5he9r_dvqTQKnnOkqtS02qQ.jar\022@7804f6ab9a49c902bca75c7d5bce8be617bdaff76fa9340a9e73a4aad4b4daa4"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-eAT2q5pJyQK8p1x9W86L5he9r_dvqTQKnnOkqtS02qQ.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-UTZiziZ3oPAMhBKkESP_1iGZIouF7eojtmkEsRvoc30.jar\022@513662ce2677a0f00c8412a41123ffd62199228b85edea23b66904b11be8737d"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-UTZiziZ3oPAMhBKkESP_1iGZIouF7eojtmkEsRvoc30.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-ZPGB77uRDC5AOKy08ig7v7wS0921ni2fYpQfHzSFeKM.jar\022@64f181efbb910c2e4038acb4f2283bbfbc12d3ddb59e2d9f62941f1f348578a3"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-ZPGB77uRDC5AOKy08ig7v7wS0921ni2fYpQfHzSFeKM.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-4wiJPg1GaUSuVvIrRFHNZbcPHE7Dixp3MEN1jxLCsmE.jar\022@e308893e0d466944ae56f22b4451cd65b70f1c4ec38b1a773043758f12c2b261"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-4wiJPg1GaUSuVvIrRFHNZbcPHE7Dixp3MEN1jxLCsmE.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\214\001/tmp/artifacts/beam-sdks-java-testing-expansion-service-testExpansionService-2.30.0-SNAPSHOT-Ne3vUpkpG-CaYdjrmkv7PqsNH0P_hFEFqCyVWnkGE7Y.jar\022@35edef5299291be09a61d8eb9a4bfb3eab0d1f43ff845105a82c955a790613b6"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n}beam-sdks-java-testing-expansion-service-testExpansionService-2.30.0-SNAPSHOT-Ne3vUpkpG-CaYdjrmkv7PqsNH0P_hFEFqCyVWnkGE7Y.jar"
      >
    >
  >
  environments: <
    key: "go"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n\026apache/beam_go_sdk:dev"
      capabilities: "beam:protocol:progress_reporting:v0"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:version:sdk_base:go"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      dependencies: <
        type_urn: "beam:artifact:type:go_worker_binary:v1"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n\006worker"
      >
    >
  >
  environments: <
    key: "go@NnaYxMUnqK"
    value: <
    >
  >
>
root_transform_ids: "e1"
root_transform_ids: "e2"
root_transform_ids: "e3"
root_transform_ids: "s1"
root_transform_ids: "e5"
root_transform_ids: "e6"
root_transform_ids: "s2"
2021/04/06 18:33:09 Prepared job with id: go-job-2-1617733989558567798_f2f6b794-6653-4069-88a9-f2f63740903d and staging token: go-job-2-1617733989558567798_f2f6b794-6653-4069-88a9-f2f63740903d
2021/04/06 18:33:09 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/temp_gopath/src/github.com/apache/beam/sdks/go/test/integration/xlang/xlang_test.go> as /tmp/worker-2-1617733989790732479
2021/04/06 18:33:24 Staged binary artifact with token: 
2021/04/06 18:33:25 Submitted job: go0job0201617733989558567798-jenkins-0406183324-778dc66e_4bce5fac-feee-4d16-9f67-5deba9836275
2021/04/06 18:33:26 Job state: STOPPED
2021/04/06 18:33:26 Job state: STARTING
2021/04/06 18:33:26 Job state: RUNNING
2021/04/06 18:33:26  (): java.lang.IllegalArgumentException: A PCollectionNode should have exactly one producing PTransformNode, but found 2:
PCollection:
PCollectionNode{id=n3, PCollection=unique_name: "n3"
coder_id: "c2@NnaYxMUnqK"
is_bounded: BOUNDED
windowing_strategy_id: "w0@NnaYxMUnqK"
}
Producers:
[PTransformNode{id=impulse_i0, transform=spec {
  urn: "beam:transform:impulse:v1"
}
outputs {
  key: "out"
  value: "n3"
}
unique_name: "impulse_i0"
}, PTransformNode{id=e3, transform=spec {
  urn: "beam:transform:pardo:v1"
  payload: "\n\246\003\n\031beam:go:transform:dofn:v1\032\210\003ChliZWFtOmdvOnRyYW5zZm9ybTpkb2ZuOnYxEocCCpwBCpkBCkJnaXRodWIuY29tL2FwYWNoZS9iZWFtL3Nka3MvZ28vdGVzdC9pbnRlZ3JhdGlvbi94bGFuZy5nZXRTdHJpbmdJbnQSUwgWIkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50IgoIFiICCAwiAggGEkkIARJFCkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50GhQKEgoECBlACxIECgIIDBIECgIIBiIFUGFyRG8="
}
inputs {
  key: "i0"
  value: "n2"
}
outputs {
  key: "i0"
  value: "n3"
}
unique_name: "github.com/apache/beam/sdks/go/test/integration/xlang.getStringInt"
environment_id: "go"
}]
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:163)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.buildNetwork(QueryablePipeline.java:206)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.<init>(QueryablePipeline.java:127)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.forPrimitivesIn(QueryablePipeline.java:90)
	at org.apache.beam.runners.core.construction.graph.GreedyPipelineFuser.<init>(GreedyPipelineFuser.java:70)
	at org.apache.beam.runners.core.construction.graph.GreedyPipelineFuser.fuse(GreedyPipelineFuser.java:93)
	at org.apache.beam.runners.flink.FlinkPipelineRunner.runPipelineWithTranslator(FlinkPipelineRunner.java:120)
	at org.apache.beam.runners.flink.FlinkPipelineRunner.run(FlinkPipelineRunner.java:93)
	at org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:86)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
2021/04/06 18:33:26  (): java.lang.IllegalArgumentException: A PCollectionNode should have exactly one producing PTransformNode, but found 2:
PCollection:
PCollectionNode{id=n3, PCollection=unique_name: "n3"
coder_id: "c2@NnaYxMUnqK"
is_bounded: BOUNDED
windowing_strategy_id: "w0@NnaYxMUnqK"
}
Producers:
[PTransformNode{id=impulse_i0, transform=spec {
  urn: "beam:transform:impulse:v1"
}
outputs {
  key: "out"
  value: "n3"
}
unique_name: "impulse_i0"
}, PTransformNode{id=e3, transform=spec {
  urn: "beam:transform:pardo:v1"
  payload: "\n\246\003\n\031beam:go:transform:dofn:v1\032\210\003ChliZWFtOmdvOnRyYW5zZm9ybTpkb2ZuOnYxEocCCpwBCpkBCkJnaXRodWIuY29tL2FwYWNoZS9iZWFtL3Nka3MvZ28vdGVzdC9pbnRlZ3JhdGlvbi94bGFuZy5nZXRTdHJpbmdJbnQSUwgWIkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50IgoIFiICCAwiAggGEkkIARJFCkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50GhQKEgoECBlACxIECgIIDBIECgIIBiIFUGFyRG8="
}
inputs {
  key: "i0"
  value: "n2"
}
outputs {
  key: "i0"
  value: "n3"
}
unique_name: "github.com/apache/beam/sdks/go/test/integration/xlang.getStringInt"
environment_id: "go"
}]
2021/04/06 18:33:26 Job state: FAILED
--- FAIL: TestXLang_GroupBy (20.98s)
    ptest.go:94: Failed to execute job: job go0job0201617733989558567798-jenkins-0406183324-778dc66e_4bce5fac-feee-4d16-9f67-5deba9836275 failed
=== RUN   TestXLang_Multi
--- SKIP: TestXLang_Multi (0.00s)
    integration.go:107: Test TestXLang_Multi is currently sickbayed on all runners
=== RUN   TestXLang_Partition
--- SKIP: TestXLang_Partition (0.00s)
    integration.go:107: Test TestXLang_Partition is currently sickbayed on all runners
FAIL
FAIL	github.com/apache/beam/sdks/go/test/integration/xlang	64.989s
Apr 06, 2021 6:36:43 PM org.apache.flink.runtime.filecache.FileCache shutdown
INFO: removed file cache directory /tmp/flink-dist-cache-e4dc5a29-33d4-4e3c-9495-d5984a0c3450
Apr 06, 2021 6:36:43 PM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException
INFO: Stopped TaskExecutor akka://flink/user/rpc/taskmanager_56.

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 36m 20s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

Publishing build scan...
https://gradle.com/s/54eym3hmeuzv4

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4590

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

Changes:


------------------------------------------
[...truncated 1.18 MB...]
INFO: CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1) (8b1f1ea36d981dd9cfdd0642149b73cb) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:12 PM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1)#0 (1dee8114d32a5772ed453e33c0178973) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:12 PM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for GroupReduce (GroupReduce at CoGBK) (1/1)#0 (1dee8114d32a5772ed453e33c0178973).
Apr 06, 2021 12:12:12 PM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task GroupReduce (GroupReduce at CoGBK) (1/1)#0 1dee8114d32a5772ed453e33c0178973.
Apr 06, 2021 12:12:12 PM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1) (1dee8114d32a5772ed453e33c0178973) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:12 PM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSource: 1 elements in 5561178483 ns
Apr 06, 2021 12:12:12 PM org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient unref
INFO: Closing environment urn: "beam:env:docker:v1"
payload: "\n\026apache/beam_go_sdk:dev"
capabilities: "beam:protocol:progress_reporting:v0"
capabilities: "beam:protocol:multi_core_bundle_processing:v1"
capabilities: "beam:version:sdk_base:go"
capabilities: "beam:coder:bytes:v1"
capabilities: "beam:coder:bool:v1"
capabilities: "beam:coder:varint:v1"
capabilities: "beam:coder:double:v1"
capabilities: "beam:coder:string_utf8:v1"
capabilities: "beam:coder:length_prefix:v1"
capabilities: "beam:coder:kv:v1"
capabilities: "beam:coder:iterable:v1"
capabilities: "beam:coder:state_backed_iterable:v1"
capabilities: "beam:coder:windowed_value:v1"
capabilities: "beam:coder:global_window:v1"
capabilities: "beam:coder:interval_window:v1"
dependencies {
  type_urn: "beam:artifact:type:file:v1"
  type_payload: "\ng/tmp/beam-artifact-staging/a88ba56776f07501b5ba78cfec41d459a4b072526354511795e51914e97565f9/1-go-worker"
  role_urn: "beam:artifact:role:staging_to:v1"
  role_payload: "\n\006worker"
}

Apr 06, 2021 12:12:12 PM org.apache.beam.runners.fnexecution.logging.GrpcLoggingService close
INFO: 1 Beam Fn Logging clients still connected during shutdown.
Apr 06, 2021 12:12:12 PM org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer$InboundObserver onCompleted
WARNING: Hanged up for unknown endpoint.
Apr 06, 2021 12:12:14 PM org.apache.beam.runners.fnexecution.environment.DockerContainerEnvironment close
INFO: Closing Docker container e68b3d8444e5f11afa576dbbd336297a5f435151eee3d0c5f5e6ce220fcae791. Logs:
2021/04/06 12:12:06 Provision info:
pipeline_options:{fields:{key:"beam:option:app_name:v1"  value:{string_value:"go-job-8-1617711118763346098"}}  fields:{key:"beam:option:experiments:v1"  value:{list_value:{values:{string_value:"beam_fn_api"}}}}  fields:{key:"beam:option:flink_master:v1"  value:{string_value:"[local]"}}  fields:{key:"beam:option:go_options:v1"  value:{struct_value:{fields:{key:"options"  value:{struct_value:{fields:{key:"hooks"  value:{string_value:"{}"}}}}}}}}  fields:{key:"beam:option:job_name:v1"  value:{string_value:"go0job0801617711118763346098-jenkins-0406121203-c4a625e"}}  fields:{key:"beam:option:options_id:v1"  value:{number_value:17}}  fields:{key:"beam:option:output_executable_path:v1"  value:{null_value:NULL_VALUE}}  fields:{key:"beam:option:parallelism:v1"  value:{number_value:-1}}  fields:{key:"beam:option:retain_docker_containers:v1"  value:{bool_value:false}}  fields:{key:"beam:option:runner:v1"  value:{null_value:NULL_VALUE}}}  logging_endpoint:{url:"localhost:42925"}  artifact_endpoint:{url:"localhost:35737"}  control_endpoint:{url:"localhost:42919"}  dependencies:{type_urn:"beam:artifact:type:file:v1"  type_payload:"\ng/tmp/beam-artifact-staging/a88ba56776f07501b5ba78cfec41d459a4b072526354511795e51914e97565f9/1-go-worker"  role_urn:"beam:artifact:role:staging_to:v1"  role_payload:"\n\x06worker"}
2021/04/06 12:12:06 Initializing Go harness: /opt/apache/beam/boot --id=15-1 --provision_endpoint=localhost:40645
2021/04/06 12:12:07 WARNING: proto: file "v1.proto" is already registered
A future release will panic on registration conflicts. See:
https://developers.google.com/protocol-buffers/docs/reference/go/faq#namespace-conflict

Worker exited successfully!
2021/04/06 12:12:12 control response channel closed
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (b453e6c23252bd2c0d89aaf834d9cb88) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (b453e6c23252bd2c0d89aaf834d9cb88).
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1)#0 (929d7b573c8f094dca2078ab684dba6c) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for DataSink (DiscardingOutput) (1/1)#0 (929d7b573c8f094dca2078ab684dba6c).
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 b453e6c23252bd2c0d89aaf834d9cb88.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task DataSink (DiscardingOutput) (1/1)#0 929d7b573c8f094dca2078ab684dba6c.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1) (b453e6c23252bd2c0d89aaf834d9cb88) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (929d7b573c8f094dca2078ab684dba6c) switched from RUNNING to FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
INFO: Job go0job0801617711118763346098-jenkins-0406121203-c4a625e (e4f0b40f8fcb84b703d68afb144497bb) switched from state RUNNING to FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.minicluster.MiniCluster closeAsync
INFO: Shutting down Flink Mini Cluster
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.dispatcher.Dispatcher jobReachedGloballyTerminalState
INFO: Job e4f0b40f8fcb84b703d68afb144497bb reached globally terminal state FINISHED.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rest.RestServerEndpoint closeAsync
INFO: Shutting down rest endpoint.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor onStop
INFO: Stopping TaskExecutor akka://flink/user/rpc/taskmanager_56.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.jobmaster.JobMaster onStop
INFO: Stopping the JobMaster for job go0job0801617711118763346098-jenkins-0406121203-c4a625e(e4f0b40f8fcb84b703d68afb144497bb).
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeResourceManagerConnection
INFO: Close ResourceManager connection 992d7702ecb86889e27d32afe894f478.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor disconnectJobManagerConnection
INFO: Close JobManager connection for job e4f0b40f8fcb84b703d68afb144497bb.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.resourcemanager.ResourceManager closeTaskManagerConnection
INFO: Closing TaskExecutor connection 97d6ed8e-5b7e-4052-bc71-663b909c4b0c because: The TaskExecutor is shutting down.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl suspend
INFO: Suspending SlotPool.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
INFO: Close ResourceManager connection 992d7702ecb86889e27d32afe894f478: Stopping JobMaster for job go0job0801617711118763346098-jenkins-0406121203-c4a625e(e4f0b40f8fcb84b703d68afb144497bb)..
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl close
INFO: Stopping SlotPool.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
INFO: Disconnect job manager 91c51c43af5718198df9f81cb8564156@akka://flink/user/rpc/jobmanager_59 for job e4f0b40f8fcb84b703d68afb144497bb from the resource manager.
Apr 06, 2021 12:12:15 PM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Execution finished in 10782 msecs
Apr 06, 2021 12:12:15 PM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Final accumulator values:
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{managedMemory=9.082gb (9751231488 bytes), networkMemory=64.000mb (67108864 bytes)}, allocationId: 0fa52d96e287593104746b9d42cbd229, jobId: e4f0b40f8fcb84b703d68afb144497bb).
Apr 06, 2021 12:12:15 PM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: __metricscontainers : {
  "metrics": {
    "attempted": [{
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n4:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n4"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n7:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n7"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n1"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n1:0"
      }
    }]
  }
}
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor$JobLeaderListenerImpl jobManagerLostLeadership
INFO: JobManager for job e4f0b40f8fcb84b703d68afb144497bb with leader id 91c51c43af5718198df9f81cb8564156 lost leadership.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.
Apr 06, 2021 12:12:15 PM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Getting job metrics for go0job0801617711118763346098-jenkins-0406121203-c4a625e_a38891dc-e58d-4125-81e4-95a76d0415b1
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint lambda$shutDownInternal$5
INFO: Removing cache directory /tmp/flink-web-ui
Apr 06, 2021 12:12:15 PM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Finished getting job metrics for go0job0801617711118763346098-jenkins-0406121203-c4a625e_a38891dc-e58d-4125-81e4-95a76d0415b1
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-io-447a4bcc-79a5-4d82-81f8-0681b9dd9796
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.io.network.NettyShuffleEnvironment close
INFO: Shutting down the network environment and its components.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rest.RestServerEndpoint lambda$closeAsync$1
INFO: Shut down complete.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.resourcemanager.ResourceManager deregisterApplication
INFO: Shut down cluster because application is in CANCELED, diagnostics DispatcherResourceManagerComponent has been closed..
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-netty-shuffle-f957e673-1fb9-441f-a64f-d85fec256a40
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.KvStateService shutdown
INFO: Shutting down the kvState service and its components.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent closeAsyncInternal
INFO: Closing components.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.filecache.FileCache shutdown
INFO: removed file cache directory /tmp/flink-dist-cache-ff7e6826-9f16-4060-83ed-a3175352bea5
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess closeInternal
INFO: Stopping SessionDispatcherLeaderProcess.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException
INFO: Stopped TaskExecutor akka://flink/user/rpc/taskmanager_56.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.dispatcher.Dispatcher onStop
INFO: Stopping dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl close
INFO: Closing the SlotManager.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.dispatcher.Dispatcher terminateRunningJobs
INFO: Stopping all currently running jobs of dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl suspend
INFO: Suspending the SlotManager.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureRequestCoordinator shutDown
INFO: Shutting down back pressure request coordinator.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.dispatcher.Dispatcher lambda$onStop$0
INFO: Stopped dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$7
INFO: Stopped Akka RPC service.
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.blob.BlobServer close
INFO: Stopped BLOB server at 0.0.0.0:45829
Apr 06, 2021 12:12:15 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$7
INFO: Stopped Akka RPC service.

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 11m 51s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4589

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

Changes:

[kileysok] Optimize reservoir sampling calculation


------------------------------------------
[...truncated 1.17 MB...]
Apr 06, 2021 6:18:42 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1) (bc2b2ccdeadeb2de8c1e5b9402cd0906) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:42 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1)#0 (892d8a866e8693646e19de3fb1e516b3) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:42 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for GroupReduce (GroupReduce at CoGBK) (1/1)#0 (892d8a866e8693646e19de3fb1e516b3).
Apr 06, 2021 6:18:42 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task GroupReduce (GroupReduce at CoGBK) (1/1)#0 892d8a866e8693646e19de3fb1e516b3.
Apr 06, 2021 6:18:42 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1) (892d8a866e8693646e19de3fb1e516b3) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:42 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSource: 1 elements in 941617557 ns
Apr 06, 2021 6:18:42 AM org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient unref
INFO: Closing environment urn: "beam:env:docker:v1"
payload: "\n\026apache/beam_go_sdk:dev"
capabilities: "beam:protocol:progress_reporting:v0"
capabilities: "beam:protocol:multi_core_bundle_processing:v1"
capabilities: "beam:version:sdk_base:go"
capabilities: "beam:coder:bytes:v1"
capabilities: "beam:coder:bool:v1"
capabilities: "beam:coder:varint:v1"
capabilities: "beam:coder:double:v1"
capabilities: "beam:coder:string_utf8:v1"
capabilities: "beam:coder:length_prefix:v1"
capabilities: "beam:coder:kv:v1"
capabilities: "beam:coder:iterable:v1"
capabilities: "beam:coder:state_backed_iterable:v1"
capabilities: "beam:coder:windowed_value:v1"
capabilities: "beam:coder:global_window:v1"
capabilities: "beam:coder:interval_window:v1"
dependencies {
  type_urn: "beam:artifact:type:file:v1"
  type_payload: "\ng/tmp/beam-artifact-staging/51e6f5d8d1e058562d9d41bd6dd3f5275e5ef13ed263fa5ed2965587981b0398/1-go-worker"
  role_urn: "beam:artifact:role:staging_to:v1"
  role_payload: "\n\006worker"
}

Apr 06, 2021 6:18:42 AM org.apache.beam.runners.fnexecution.logging.GrpcLoggingService close
INFO: 1 Beam Fn Logging clients still connected during shutdown.
Apr 06, 2021 6:18:42 AM org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer$InboundObserver onCompleted
WARNING: Hanged up for unknown endpoint.
Apr 06, 2021 6:18:42 AM org.apache.beam.runners.fnexecution.environment.DockerContainerEnvironment close
INFO: Closing Docker container aaf9a2840b90790d6dbffe61acccb60d1cd68924f645790a9c478926d4b2de5f. Logs:
2021/04/06 06:18:41 Provision info:
pipeline_options:{fields:{key:"beam:option:app_name:v1"  value:{string_value:"go-job-8-1617689916884342961"}}  fields:{key:"beam:option:experiments:v1"  value:{list_value:{values:{string_value:"beam_fn_api"}}}}  fields:{key:"beam:option:flink_master:v1"  value:{string_value:"[local]"}}  fields:{key:"beam:option:go_options:v1"  value:{struct_value:{fields:{key:"options"  value:{struct_value:{fields:{key:"hooks"  value:{string_value:"{}"}}}}}}}}  fields:{key:"beam:option:job_name:v1"  value:{string_value:"go0job0801617689916884342961-jenkins-0406061839-b95c0958"}}  fields:{key:"beam:option:options_id:v1"  value:{number_value:17}}  fields:{key:"beam:option:output_executable_path:v1"  value:{null_value:NULL_VALUE}}  fields:{key:"beam:option:parallelism:v1"  value:{number_value:-1}}  fields:{key:"beam:option:retain_docker_containers:v1"  value:{bool_value:false}}  fields:{key:"beam:option:runner:v1"  value:{null_value:NULL_VALUE}}}  logging_endpoint:{url:"localhost:39013"}  artifact_endpoint:{url:"localhost:34689"}  control_endpoint:{url:"localhost:39517"}  dependencies:{type_urn:"beam:artifact:type:file:v1"  type_payload:"\ng/tmp/beam-artifact-staging/51e6f5d8d1e058562d9d41bd6dd3f5275e5ef13ed263fa5ed2965587981b0398/1-go-worker"  role_urn:"beam:artifact:role:staging_to:v1"  role_payload:"\n\x06worker"}
2021/04/06 06:18:41 Initializing Go harness: /opt/apache/beam/boot --id=15-1 --provision_endpoint=localhost:44841
2021/04/06 06:18:41 WARNING: proto: file "v1.proto" is already registered
A future release will panic on registration conflicts. See:
https://developers.google.com/protocol-buffers/docs/reference/go/faq#namespace-conflict

Worker exited successfully!
2021/04/06 06:18:42 control response channel closed
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (9846f8cefe323718e5f9b403f2bbefa0) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (9846f8cefe323718e5f9b403f2bbefa0).
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1)#0 (831606107b706d6a0c0bc4c74f468ec2) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 9846f8cefe323718e5f9b403f2bbefa0.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for DataSink (DiscardingOutput) (1/1)#0 (831606107b706d6a0c0bc4c74f468ec2).
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task DataSink (DiscardingOutput) (1/1)#0 831606107b706d6a0c0bc4c74f468ec2.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1) (9846f8cefe323718e5f9b403f2bbefa0) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (831606107b706d6a0c0bc4c74f468ec2) switched from RUNNING to FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
INFO: Job go0job0801617689916884342961-jenkins-0406061839-b95c0958 (7ec1ddda879ac3fab43b1d04ee2c93fe) switched from state RUNNING to FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.dispatcher.Dispatcher jobReachedGloballyTerminalState
INFO: Job 7ec1ddda879ac3fab43b1d04ee2c93fe reached globally terminal state FINISHED.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.minicluster.MiniCluster closeAsync
INFO: Shutting down Flink Mini Cluster
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rest.RestServerEndpoint closeAsync
INFO: Shutting down rest endpoint.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.jobmaster.JobMaster onStop
INFO: Stopping the JobMaster for job go0job0801617689916884342961-jenkins-0406061839-b95c0958(7ec1ddda879ac3fab43b1d04ee2c93fe).
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor onStop
INFO: Stopping TaskExecutor akka://flink/user/rpc/taskmanager_56.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor closeResourceManagerConnection
INFO: Close ResourceManager connection 64849936480eee56fb0237d94da9276b.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeTaskManagerConnection
INFO: Closing TaskExecutor connection 7fece321-330d-45e6-b5c4-4c65a75538cd because: The TaskExecutor is shutting down.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor disconnectJobManagerConnection
INFO: Close JobManager connection for job 7ec1ddda879ac3fab43b1d04ee2c93fe.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl suspend
INFO: Suspending SlotPool.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
INFO: Close ResourceManager connection 64849936480eee56fb0237d94da9276b: Stopping JobMaster for job go0job0801617689916884342961-jenkins-0406061839-b95c0958(7ec1ddda879ac3fab43b1d04ee2c93fe)..
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl close
INFO: Stopping SlotPool.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
INFO: Disconnect job manager ac11f915a001c5e0f1df2154782a4235@akka://flink/user/rpc/jobmanager_59 for job 7ec1ddda879ac3fab43b1d04ee2c93fe from the resource manager.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{managedMemory=9.082gb (9751277568 bytes), networkMemory=64.000mb (67108864 bytes)}, allocationId: afaa2626d1a98db2cb9092953d4998b3, jobId: 7ec1ddda879ac3fab43b1d04ee2c93fe).
Apr 06, 2021 6:18:43 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Execution finished in 3240 msecs
Apr 06, 2021 6:18:43 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Final accumulator values:
Apr 06, 2021 6:18:43 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: __metricscontainers : {
  "metrics": {
    "attempted": [{
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n4:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n4"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n7:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n7"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n1"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n1:0"
      }
    }]
  }
}
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor$JobLeaderListenerImpl jobManagerLostLeadership
INFO: JobManager for job 7ec1ddda879ac3fab43b1d04ee2c93fe with leader id ac11f915a001c5e0f1df2154782a4235 lost leadership.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-io-11d20603-3963-4fc2-bf22-5d5b15b173dc
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.io.network.NettyShuffleEnvironment close
INFO: Shutting down the network environment and its components.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint lambda$shutDownInternal$5
INFO: Removing cache directory /tmp/flink-web-ui
Apr 06, 2021 6:18:43 AM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Getting job metrics for go0job0801617689916884342961-jenkins-0406061839-b95c0958_49beb3a0-0398-4449-91b0-db164d412328
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rest.RestServerEndpoint lambda$closeAsync$1
INFO: Shut down complete.
Apr 06, 2021 6:18:43 AM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Finished getting job metrics for go0job0801617689916884342961-jenkins-0406061839-b95c0958_49beb3a0-0398-4449-91b0-db164d412328
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-netty-shuffle-6d64c7d0-1c3e-4688-b472-df7a25334840
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.KvStateService shutdown
INFO: Shutting down the kvState service and its components.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.resourcemanager.ResourceManager deregisterApplication
INFO: Shut down cluster because application is in CANCELED, diagnostics DispatcherResourceManagerComponent has been closed..
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.filecache.FileCache shutdown
INFO: removed file cache directory /tmp/flink-dist-cache-f1e485be-dea4-456f-9177-07d00efc3f88
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent closeAsyncInternal
INFO: Closing components.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException
INFO: Stopped TaskExecutor akka://flink/user/rpc/taskmanager_56.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess closeInternal
INFO: Stopping SessionDispatcherLeaderProcess.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.dispatcher.Dispatcher onStop
INFO: Stopping dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl close
INFO: Closing the SlotManager.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.dispatcher.Dispatcher terminateRunningJobs
INFO: Stopping all currently running jobs of dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl suspend
INFO: Suspending the SlotManager.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureRequestCoordinator shutDown
INFO: Shutting down back pressure request coordinator.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.dispatcher.Dispatcher lambda$onStop$0
INFO: Stopped dispatcher akka://flink/user/rpc/dispatcher_58.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
INFO: Stopping Akka RPC service.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$7
INFO: Stopped Akka RPC service.
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.blob.AbstractBlobCache close
INFO: Shutting down BLOB cache
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.blob.BlobServer close
INFO: Stopped BLOB server at 0.0.0.0:42705
Apr 06, 2021 6:18:43 AM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$7
INFO: Stopped Akka RPC service.

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 18m 17s
139 actionable tasks: 98 executed, 39 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4588

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

Changes:


------------------------------------------
[...truncated 1.17 MB...]
INFO: getProcessBundleDescriptor request with id 15-2
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: Connecting via grpc @ localhost:36483 ...
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.data.GrpcDataService data
INFO: Beam Fn Data client connected.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate convertRecoveredInputChannels
INFO: Converting recovered input channels (1 channels)
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate convertRecoveredInputChannels
INFO: Converting recovered input channels (1 channels)
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSource: 1 elements in 5022342 ns
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSink: 9 elements in 4090062 ns
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: CHAIN MapPartition (MapPartition at [3]{github.com, e5_keyed1}) -> FlatMap (FlatMap at ExtractOutput[0]) (1/1)#0 (34a7555f8b093cab19c7edf80b9462cb) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for CHAIN MapPartition (MapPartition at [3]{github.com, e5_keyed1}) -> FlatMap (FlatMap at ExtractOutput[0]) (1/1)#0 (34a7555f8b093cab19c7edf80b9462cb).
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task CHAIN MapPartition (MapPartition at [3]{github.com, e5_keyed1}) -> FlatMap (FlatMap at ExtractOutput[0]) (1/1)#0 34a7555f8b093cab19c7edf80b9462cb.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: CHAIN MapPartition (MapPartition at [3]{github.com, e5_keyed1}) -> FlatMap (FlatMap at ExtractOutput[0]) (1/1) (34a7555f8b093cab19c7edf80b9462cb) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate convertRecoveredInputChannels
INFO: Converting recovered input channels (1 channels)
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.control.FnApiControlClientPoolService getProcessBundleDescriptor
INFO: getProcessBundleDescriptor request with id 15-4
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: Connecting via grpc @ localhost:37517 ...
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSource: 1 elements in 4197657 ns
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSink: 1 elements in 4221550 ns
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1)#0 (10b1f35e9aabc1c8bd28ab5f753538b2) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1)#0 (10b1f35e9aabc1c8bd28ab5f753538b2).
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1)#0 10b1f35e9aabc1c8bd28ab5f753538b2.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: CHAIN MapPartition (MapPartition at [2]github.com/apache/beam/sdks/go/test/{integration, vendor}) -> FlatMap (FlatMap at ExtractOutput[0]) -> Map (Key Extractor) -> GroupCombine (GroupCombine at GroupCombine: CoGBK) -> Map (Key Extractor) (1/1) (10b1f35e9aabc1c8bd28ab5f753538b2) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1)#0 (c000cad05fab4f2dddb7a936a59d0d41) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for GroupReduce (GroupReduce at CoGBK) (1/1)#0 (c000cad05fab4f2dddb7a936a59d0d41).
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task GroupReduce (GroupReduce at CoGBK) (1/1)#0 c000cad05fab4f2dddb7a936a59d0d41.
Apr 06, 2021 12:11:52 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: GroupReduce (GroupReduce at CoGBK) (1/1) (c000cad05fab4f2dddb7a936a59d0d41) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.Slf4jLogWriter log
INFO: DataSource: 1 elements in 862761526 ns
Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.control.DefaultJobBundleFactory$WrappedSdkHarnessClient unref
INFO: Closing environment urn: "beam:env:docker:v1"
payload: "\n\026apache/beam_go_sdk:dev"
capabilities: "beam:protocol:progress_reporting:v0"
capabilities: "beam:protocol:multi_core_bundle_processing:v1"
capabilities: "beam:version:sdk_base:go"
capabilities: "beam:coder:bytes:v1"
capabilities: "beam:coder:bool:v1"
capabilities: "beam:coder:varint:v1"
capabilities: "beam:coder:double:v1"
capabilities: "beam:coder:string_utf8:v1"
capabilities: "beam:coder:length_prefix:v1"
capabilities: "beam:coder:kv:v1"
capabilities: "beam:coder:iterable:v1"
capabilities: "beam:coder:state_backed_iterable:v1"
capabilities: "beam:coder:windowed_value:v1"
capabilities: "beam:coder:global_window:v1"
capabilities: "beam:coder:interval_window:v1"
dependencies {
  type_urn: "beam:artifact:type:file:v1"
  type_payload: "\ng/tmp/beam-artifact-staging/93eea04f854c7d5dca7a594c4c52b8c94d2a58ef9318ba4dc0b6ec629e2cf223/1-go-worker"
  role_urn: "beam:artifact:role:staging_to:v1"
  role_payload: "\n\006worker"
}

Apr 06, 2021 12:11:52 AM org.apache.beam.runners.fnexecution.logging.GrpcLoggingService close
INFO: 1 Beam Fn Logging clients still connected during shutdown.
Apr 06, 2021 12:11:52 AM org.apache.beam.sdk.fn.data.BeamFnDataGrpcMultiplexer$InboundObserver onCompleted
WARNING: Hanged up for unknown endpoint.
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.fnexecution.environment.DockerContainerEnvironment close
INFO: Closing Docker container 55ed52c011b1669a25c2701bff1f0014b8ffe0dd9510d1d975d9026a69ecd790. Logs:
2021/04/06 00:11:51 Provision info:
pipeline_options:{fields:{key:"beam:option:app_name:v1"  value:{string_value:"go-job-8-1617667905941248736"}}  fields:{key:"beam:option:experiments:v1"  value:{list_value:{values:{string_value:"beam_fn_api"}}}}  fields:{key:"beam:option:flink_master:v1"  value:{string_value:"[local]"}}  fields:{key:"beam:option:go_options:v1"  value:{struct_value:{fields:{key:"options"  value:{struct_value:{fields:{key:"hooks"  value:{string_value:"{}"}}}}}}}}  fields:{key:"beam:option:job_name:v1"  value:{string_value:"go0job0801617667905941248736-jenkins-0406001149-801d1868"}}  fields:{key:"beam:option:options_id:v1"  value:{number_value:17}}  fields:{key:"beam:option:output_executable_path:v1"  value:{null_value:NULL_VALUE}}  fields:{key:"beam:option:parallelism:v1"  value:{number_value:-1}}  fields:{key:"beam:option:retain_docker_containers:v1"  value:{bool_value:false}}  fields:{key:"beam:option:runner:v1"  value:{null_value:NULL_VALUE}}}  logging_endpoint:{url:"localhost:43229"}  artifact_endpoint:{url:"localhost:42025"}  control_endpoint:{url:"localhost:41557"}  dependencies:{type_urn:"beam:artifact:type:file:v1"  type_payload:"\ng/tmp/beam-artifact-staging/93eea04f854c7d5dca7a594c4c52b8c94d2a58ef9318ba4dc0b6ec629e2cf223/1-go-worker"  role_urn:"beam:artifact:role:staging_to:v1"  role_payload:"\n\x06worker"}
2021/04/06 00:11:51 Initializing Go harness: /opt/apache/beam/boot --id=15-1 --provision_endpoint=localhost:37307
2021/04/06 00:11:52 WARNING: proto: file "v1.proto" is already registered
A future release will panic on registration conflicts. See:
https://developers.google.com/protocol-buffers/docs/reference/go/faq#namespace-conflict

Worker exited successfully!
2021/04/06 00:11:52 control response channel closed
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (27277a9fb0c77c860041cdcf87336c1c) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 (27277a9fb0c77c860041cdcf87336c1c).
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskmanager.Task transitionState
INFO: DataSink (DiscardingOutput) (1/1)#0 (36e71004940e730eb3bd2cd64620f91a) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskmanager.Task doRun
INFO: Freeing task resources for DataSink (DiscardingOutput) (1/1)#0 (36e71004940e730eb3bd2cd64620f91a).
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1)#0 27277a9fb0c77c860041cdcf87336c1c.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
INFO: Un-registering task and sending final execution state FINISHED to JobManager for task DataSink (DiscardingOutput) (1/1)#0 36e71004940e730eb3bd2cd64620f91a.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: MapPartition (MapPartition at [1]github.com/apache/beam/sdks/go/test/vendor/github.com/apache/beam/sdks/go/pkg/beam/testing/passert.sumFn) (1/1) (27277a9fb0c77c860041cdcf87336c1c) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.executiongraph.Execution transitionState
INFO: DataSink (DiscardingOutput) (1/1) (36e71004940e730eb3bd2cd64620f91a) switched from RUNNING to FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
INFO: Job go0job0801617667905941248736-jenkins-0406001149-801d1868 (ae4607adad48713ec88ae69356c4a891) switched from state RUNNING to FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.dispatcher.Dispatcher jobReachedGloballyTerminalState
INFO: Job ae4607adad48713ec88ae69356c4a891 reached globally terminal state FINISHED.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.minicluster.MiniCluster closeAsync
INFO: Shutting down Flink Mini Cluster
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.jobmaster.JobMaster onStop
INFO: Stopping the JobMaster for job go0job0801617667905941248736-jenkins-0406001149-801d1868(ae4607adad48713ec88ae69356c4a891).
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor onStop
INFO: Stopping TaskExecutor akka://flink/user/rpc/taskmanager_56.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.rest.RestServerEndpoint closeAsync
INFO: Shutting down rest endpoint.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor closeResourceManagerConnection
INFO: Close ResourceManager connection df6716d3ba167966a9c7a9fa69a958a1.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor disconnectJobManagerConnection
INFO: Close JobManager connection for job ae4607adad48713ec88ae69356c4a891.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeTaskManagerConnection
INFO: Closing TaskExecutor connection 3b270973-431e-4654-ba51-3afe7f545a7c because: The TaskExecutor is shutting down.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl suspend
INFO: Suspending SlotPool.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
INFO: Close ResourceManager connection df6716d3ba167966a9c7a9fa69a958a1: Stopping JobMaster for job go0job0801617667905941248736-jenkins-0406001149-801d1868(ae4607adad48713ec88ae69356c4a891)..
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl close
INFO: Stopping SlotPool.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
INFO: Disconnect job manager b7f8dc116f23043911a15ad9d8fa43eb@akka://flink/user/rpc/jobmanager_59 for job ae4607adad48713ec88ae69356c4a891 from the resource manager.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl freeSlotInternal
INFO: Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{managedMemory=9.082gb (9751348224 bytes), networkMemory=64.000mb (67108864 bytes)}, allocationId: 129a0b22f2505ceba5a9e7ad444e038d, jobId: ae4607adad48713ec88ae69356c4a891).
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Execution finished in 4239 msecs
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: Final accumulator values:
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
INFO: Shutting down TaskExecutorLocalStateStoresManager.
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.flink.FlinkPipelineRunner createPortablePipelineResult
INFO: __metricscontainers : {
  "metrics": {
    "attempted": [{
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n4:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n4"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n7:0"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n7"
      }
    }, {
      "urn": "beam:metric:element_count:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PCOLLECTION": "n1"
      }
    }, {
      "urn": "beam:metric:data_channel:read_index:v1",
      "type": "beam:metrics:sum_int64:v1",
      "payload": "AQ==",
      "labels": {
        "PTRANSFORM": "fn/read/n1:0"
      }
    }]
  }
}
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Getting job metrics for go0job0801617667905941248736-jenkins-0406001149-801d1868_e2abf2f3-e31f-4ecf-b6a6-7c63e5b63cd0
Apr 06, 2021 12:11:53 AM org.apache.beam.runners.jobsubmission.InMemoryJobService getJobMetrics
INFO: Finished getting job metrics for go0job0801617667905941248736-jenkins-0406001149-801d1868_e2abf2f3-e31f-4ecf-b6a6-7c63e5b63cd0
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-io-108cffeb-11cf-4fe5-b8da-aa8f46c3c2dc
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.io.network.NettyShuffleEnvironment close
INFO: Shutting down the network environment and its components.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.io.disk.FileChannelManagerImpl lambda$getFileCloser$0
INFO: FileChannelManager removed spill file directory /tmp/flink-netty-shuffle-05314c66-ac6d-49d4-90a8-2c5cc3506ca2
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.KvStateService shutdown
INFO: Shutting down the kvState service and its components.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService stop
INFO: Stop job leader service.
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.filecache.FileCache shutdown
INFO: removed file cache directory /tmp/flink-dist-cache-4d5f5f1a-2701-41ae-850d-e3c61bf18567
Apr 06, 2021 12:11:53 AM org.apache.flink.runtime.taskexecutor.TaskExecutor handleOnStopException
INFO: Stopped TaskExecutor akka://flink/user/rpc/taskmanager_56.

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 11m 25s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4587

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

Changes:

[chamikaramj] Updates Dataflow worker pool config to include all environments used by

[Kyle Weaver] [BEAM-10925] Roundtrip tests for literals through Java UDF.

[Ismaël Mejía] [BEAM-4106] Add FileStagingOptions and merge staging file options

[Kyle Weaver] [BEAM-12095] Fix Spark job server path.

[noreply] remove typo in encoding.go

[Kyle Weaver] [BEAM-10925] Simplify test setup.

[noreply] [BEAM-12060] Remove overwriting jenkins property. (#14432)


------------------------------------------
[...truncated 1.52 MB...]
      component_coder_ids: "uvbEBibknVIterableCoder"
    >
  >
  environments: <
    key: "go"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n\026apache/beam_go_sdk:dev"
      capabilities: "beam:protocol:progress_reporting:v0"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:version:sdk_base:go"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      dependencies: <
        type_urn: "beam:artifact:type:go_worker_binary:v1"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n\006worker"
      >
    >
  >
  environments: <
    key: "go@uvbEBibknV"
    value: <
    >
  >
  environments: <
    key: "uvbEBibknVbeam:env:docker:v1"
    value: <
      urn: "beam:env:docker:v1"
      payload: "\n apache/beam_java8_sdk:2.30.0.dev"
      capabilities: "beam:coder:bytes:v1"
      capabilities: "beam:coder:bool:v1"
      capabilities: "beam:coder:varint:v1"
      capabilities: "beam:coder:string_utf8:v1"
      capabilities: "beam:coder:iterable:v1"
      capabilities: "beam:coder:timer:v1"
      capabilities: "beam:coder:kv:v1"
      capabilities: "beam:coder:length_prefix:v1"
      capabilities: "beam:coder:global_window:v1"
      capabilities: "beam:coder:interval_window:v1"
      capabilities: "beam:coder:windowed_value:v1"
      capabilities: "beam:coder:double:v1"
      capabilities: "beam:coder:row:v1"
      capabilities: "beam:coder:param_windowed_value:v1"
      capabilities: "beam:coder:state_backed_iterable:v1"
      capabilities: "beam:coder:sharded_key:v1"
      capabilities: "beam:protocol:multi_core_bundle_processing:v1"
      capabilities: "beam:protocol:progress_reporting:v1"
      capabilities: "beam:version:sdk_base:apache/beam_java8_sdk:2.30.0.dev"
      capabilities: "beam:transform:sdf_truncate_sized_restrictions:v1"
      capabilities: "beam:transform:to_string:v1"
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nL/tmp/artifacts/icedtea-sound-iX5usnMhooWFVsDnq3d6iP0jxH1RLWWxipZhY6Hvsnw.jar\022@897e6eb27321a2858556c0e7ab777a88fd23c47d512d65b18a966163a1efb27c"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n=icedtea-sound-iX5usnMhooWFVsDnq3d6iP0jxH1RLWWxipZhY6Hvsnw.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/jaccess-vLiJE9Opd23Iykd81sLP70H_7nOeFCEONM7N3XuinBg.jar\022@bcb88913d3a9776dc8ca477cd6c2cfef41ffee739e14210e34cecddd7ba29c18"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7jaccess-vLiJE9Opd23Iykd81sLP70H_7nOeFCEONM7N3XuinBg.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nI/tmp/artifacts/localedata-eAT2q5pJyQK8p1x9W86L5he9r_dvqTQKnnOkqtS02qQ.jar\022@7804f6ab9a49c902bca75c7d5bce8be617bdaff76fa9340a9e73a4aad4b4daa4"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n:localedata-eAT2q5pJyQK8p1x9W86L5he9r_dvqTQKnnOkqtS02qQ.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nF/tmp/artifacts/nashorn-UTZiziZ3oPAMhBKkESP_1iGZIouF7eojtmkEsRvoc30.jar\022@513662ce2677a0f00c8412a41123ffd62199228b85edea23b66904b11be8737d"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n7nashorn-UTZiziZ3oPAMhBKkESP_1iGZIouF7eojtmkEsRvoc30.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nG/tmp/artifacts/cldrdata-ZPGB77uRDC5AOKy08ig7v7wS0921ni2fYpQfHzSFeKM.jar\022@64f181efbb910c2e4038acb4f2283bbfbc12d3ddb59e2d9f62941f1f348578a3"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n8cldrdata-ZPGB77uRDC5AOKy08ig7v7wS0921ni2fYpQfHzSFeKM.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\nD/tmp/artifacts/dnsns-4wiJPg1GaUSuVvIrRFHNZbcPHE7Dixp3MEN1jxLCsmE.jar\022@e308893e0d466944ae56f22b4451cd65b70f1c4ec38b1a773043758f12c2b261"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n5dnsns-4wiJPg1GaUSuVvIrRFHNZbcPHE7Dixp3MEN1jxLCsmE.jar"
      >
      dependencies: <
        type_urn: "beam:artifact:type:file:v1"
        type_payload: "\n\214\001/tmp/artifacts/beam-sdks-java-testing-expansion-service-testExpansionService-2.30.0-SNAPSHOT-Ne3vUpkpG-CaYdjrmkv7PqsNH0P_hFEFqCyVWnkGE7Y.jar\022@35edef5299291be09a61d8eb9a4bfb3eab0d1f43ff845105a82c955a790613b6"
        role_urn: "beam:artifact:role:staging_to:v1"
        role_payload: "\n}beam-sdks-java-testing-expansion-service-testExpansionService-2.30.0-SNAPSHOT-Ne3vUpkpG-CaYdjrmkv7PqsNH0P_hFEFqCyVWnkGE7Y.jar"
      >
    >
  >
>
root_transform_ids: "e1"
root_transform_ids: "e2"
root_transform_ids: "e3"
root_transform_ids: "s1"
root_transform_ids: "e5"
root_transform_ids: "e6"
root_transform_ids: "s2"
2021/04/05 22:50:28 Prepared job with id: go-job-2-1617663028322528277_1621490a-5e94-4029-a082-79b3c3b49f7d and staging token: go-job-2-1617663028322528277_1621490a-5e94-4029-a082-79b3c3b49f7d
2021/04/05 22:50:28 Cross-compiling <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/temp_gopath/src/github.com/apache/beam/sdks/go/test/integration/xlang/xlang_test.go> as /tmp/worker-2-1617663028398438102
2021/04/05 22:50:44 Staged binary artifact with token: 
2021/04/05 22:50:53 Submitted job: go0job0201617663028322528277-jenkins-0405225044-4f22d0f3_4e6bce9a-620f-437d-9847-9f9fc1c24780
2021/04/05 22:50:53 Job state: STOPPED
2021/04/05 22:50:53 Job state: STARTING
2021/04/05 22:50:53 Job state: RUNNING
2021/04/05 22:50:53  (): java.lang.IllegalArgumentException: A PCollectionNode should have exactly one producing PTransformNode, but found 2:
PCollection:
PCollectionNode{id=n3, PCollection=unique_name: "n3"
coder_id: "c2@uvbEBibknV"
is_bounded: BOUNDED
windowing_strategy_id: "w0@uvbEBibknV"
}
Producers:
[PTransformNode{id=impulse_i0, transform=spec {
  urn: "beam:transform:impulse:v1"
}
outputs {
  key: "out"
  value: "n3"
}
unique_name: "impulse_i0"
}, PTransformNode{id=e3, transform=spec {
  urn: "beam:transform:pardo:v1"
  payload: "\n\246\003\n\031beam:go:transform:dofn:v1\032\210\003ChliZWFtOmdvOnRyYW5zZm9ybTpkb2ZuOnYxEocCCpwBCpkBCkJnaXRodWIuY29tL2FwYWNoZS9iZWFtL3Nka3MvZ28vdGVzdC9pbnRlZ3JhdGlvbi94bGFuZy5nZXRTdHJpbmdJbnQSUwgWIkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50IgoIFiICCAwiAggGEkkIARJFCkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50GhQKEgoECBlACxIECgIIDBIECgIIBiIFUGFyRG8="
}
inputs {
  key: "i0"
  value: "n2"
}
outputs {
  key: "i0"
  value: "n3"
}
unique_name: "github.com/apache/beam/sdks/go/test/integration/xlang.getStringInt"
environment_id: "go"
}]
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.base.Preconditions.checkArgument(Preconditions.java:163)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.buildNetwork(QueryablePipeline.java:206)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.<init>(QueryablePipeline.java:127)
	at org.apache.beam.runners.core.construction.graph.QueryablePipeline.forPrimitivesIn(QueryablePipeline.java:90)
	at org.apache.beam.runners.core.construction.graph.GreedyPipelineFuser.<init>(GreedyPipelineFuser.java:70)
	at org.apache.beam.runners.core.construction.graph.GreedyPipelineFuser.fuse(GreedyPipelineFuser.java:93)
	at org.apache.beam.runners.flink.FlinkPipelineRunner.runPipelineWithTranslator(FlinkPipelineRunner.java:120)
	at org.apache.beam.runners.flink.FlinkPipelineRunner.run(FlinkPipelineRunner.java:93)
	at org.apache.beam.runners.jobsubmission.JobInvocation.runPipeline(JobInvocation.java:86)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask$TrustedFutureInterruptibleTask.runInterruptibly(TrustedListenableFutureTask.java:125)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.InterruptibleTask.run(InterruptibleTask.java:57)
	at org.apache.beam.vendor.guava.v26_0_jre.com.google.common.util.concurrent.TrustedListenableFutureTask.run(TrustedListenableFutureTask.java:78)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
2021/04/05 22:50:53  (): java.lang.IllegalArgumentException: A PCollectionNode should have exactly one producing PTransformNode, but found 2:
PCollection:
PCollectionNode{id=n3, PCollection=unique_name: "n3"
coder_id: "c2@uvbEBibknV"
is_bounded: BOUNDED
windowing_strategy_id: "w0@uvbEBibknV"
}
Producers:
[PTransformNode{id=impulse_i0, transform=spec {
  urn: "beam:transform:impulse:v1"
}
outputs {
  key: "out"
  value: "n3"
}
unique_name: "impulse_i0"
}, PTransformNode{id=e3, transform=spec {
  urn: "beam:transform:pardo:v1"
  payload: "\n\246\003\n\031beam:go:transform:dofn:v1\032\210\003ChliZWFtOmdvOnRyYW5zZm9ybTpkb2ZuOnYxEocCCpwBCpkBCkJnaXRodWIuY29tL2FwYWNoZS9iZWFtL3Nka3MvZ28vdGVzdC9pbnRlZ3JhdGlvbi94bGFuZy5nZXRTdHJpbmdJbnQSUwgWIkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50IgoIFiICCAwiAggGEkkIARJFCkMIGko/Z2l0aHViLmNvbS9hcGFjaGUvYmVhbS9zZGtzL2dvL3Rlc3QvaW50ZWdyYXRpb24veGxhbmcuU3RyaW5nSW50GhQKEgoECBlACxIECgIIDBIECgIIBiIFUGFyRG8="
}
inputs {
  key: "i0"
  value: "n2"
}
outputs {
  key: "i0"
  value: "n3"
}
unique_name: "github.com/apache/beam/sdks/go/test/integration/xlang.getStringInt"
environment_id: "go"
}]
2021/04/05 22:50:53 Job state: FAILED
--- FAIL: TestXLang_GroupBy (28.22s)
    ptest.go:94: Failed to execute job: job go0job0201617663028322528277-jenkins-0405225044-4f22d0f3_4e6bce9a-620f-437d-9847-9f9fc1c24780 failed
=== RUN   TestXLang_Multi
--- SKIP: TestXLang_Multi (0.00s)
    integration.go:107: Test TestXLang_Multi is currently sickbayed on all runners
=== RUN   TestXLang_Partition
--- SKIP: TestXLang_Partition (0.00s)
    integration.go:107: Test TestXLang_Partition is currently sickbayed on all runners
FAIL
FAIL	github.com/apache/beam/sdks/go/test/integration/xlang	40.121s

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 17m 41s
139 actionable tasks: 125 executed, 12 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4586

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

Changes:

[noreply] [BEAM-9615] Misc final schema cleanups. (#14285)

[noreply] [BEAM-12083] Nexmark Query 13. (#14404)


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision abbe14f721327d51cce02876324e7feba98581e2 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f abbe14f721327d51cce02876324e7feba98581e2 # timeout=10
Commit message: "[BEAM-12083] Nexmark Query 13. (#14404)"
 > git rev-list --no-walk c4d1ab39a7b9cebf69a0c999b42a8f5894c9e04f # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon (subsequent builds will be faster)
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 28s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4585

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

Changes:

[randomstep] [BEAM-12067] Bump elasticsearch-rest-high-level-client to 7.12.0


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision c4d1ab39a7b9cebf69a0c999b42a8f5894c9e04f (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f c4d1ab39a7b9cebf69a0c999b42a8f5894c9e04f # timeout=10
Commit message: "Merge pull request #14424: [BEAM-12067] Bump elasticsearch-rest-high-level-client to 7.12.0"
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 2 busy Daemons could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 20s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4584

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 1 busy Daemon could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 29s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4583

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 1 busy Daemon could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 23s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4582

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 2 busy Daemons could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 30s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4581

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 1 busy Daemon could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 20s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4580

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon (subsequent builds will be faster)
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 22s

Publishing build scan...
https://gradle.com/s/2uwyxsrfiicfs

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4579

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 1 busy Daemon could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 33s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4578

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

Changes:


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon (subsequent builds will be faster)
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 26s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4577

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

Changes:

[daniel.o.programmer] [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision bee495f335fefd6ec2a4d5b0ef355b6011c39bcd (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f bee495f335fefd6ec2a4d5b0ef355b6011c39bcd # timeout=10
Commit message: "Merge pull request #14407: [BEAM-12060] Fix failing Go Postcommits, jenkins support for Gradle tasks."
 > git rev-list --no-walk 5f13eff4f6cd6c45f40f1de9213a155471ede416 # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
Starting a Gradle Daemon, 1 busy Daemon could not be reused, use --status for details
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 31s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4576

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

Changes:


------------------------------------------
[...truncated 87.32 KB...]
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
Configuration on demand is an incubating feature.

> Task :sdks:go:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/.gogradle/project_gopath>

> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean

> Task :sdks:go:container:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/container/.gogradle/project_gopath>

> Task :sdks:go:resolveBuildDependencies
Resolving cached cloud.google.com/go: commit='03869a08dc16b35ad4968e92d34c5a2a2961b205', urls=[https://code.googlesource.com/gocloud]
Resolving cached github.com/Shopify/sarama: commit='541689b9f4212043471eb537fa72da507025d3ea', urls=[https://github.com/Shopify/sarama.git, git@github.com:Shopify/sarama.git]
Resolving cached github.com/armon/consul-api: commit='eb2c6b5be1b66bab83016e0b05f01b8d5496ffbd', urls=[https://github.com/armon/consul-api.git, git@github.com:armon/consul-api.git]
Resolving github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/davecgh/go-spew: commit='87df7c60d5820d0f8ae11afede5aa52325c09717', urls=[https://github.com/davecgh/go-spew.git, git@github.com:davecgh/go-spew.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/eapache/go-resiliency: commit='ef9aaa7ea8bd2448429af1a77cf41b2b3b34bdd6', urls=[https://github.com/eapache/go-resiliency.git, git@github.com:eapache/go-resiliency.git]
Resolving cached github.com/eapache/go-xerial-snappy: commit='bb955e01b9346ac19dc29eb16586c90ded99a98c', urls=[https://github.com/eapache/go-xerial-snappy.git, git@github.com:eapache/go-xerial-snappy.git]
Resolving cached github.com/eapache/queue: commit='44cc805cf13205b55f69e14bcb69867d1ae92f98', urls=[https://github.com/eapache/queue.git, git@github.com:eapache/queue.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/fsnotify/fsnotify: commit='c2828203cd70a50dcccfb2761f8b1f8ceef9a8e9', urls=[https://github.com/fsnotify/fsnotify.git, git@github.com:fsnotify/fsnotify.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/glog: commit='23def4e6c14b4da8ac2ed8007337bc5eb5007998', urls=[https://github.com/golang/glog.git, git@github.com:golang/glog.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/mock: commit='b3e60bcdc577185fce3cf625fc96b62857ce5574', urls=[https://github.com/golang/mock.git, git@github.com:golang/mock.git]
Resolving cached github.com/golang/protobuf: commit='d04d7b157bb510b1e0c10132224b616ac0e26b17', urls=[https://github.com/golang/protobuf.git, git@github.com:golang/protobuf.git]
Resolving cached github.com/golang/snappy: commit='553a641470496b2327abcac10b36396bd98e45c9', urls=[https://github.com/golang/snappy.git, git@github.com:golang/snappy.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/google/go-cmp: commit='9680bfaf28748393e28e00238d94070fb9972fd8', urls=[https://github.com/google/go-cmp.git, git@github.com:google/go-cmp.git]
Resolving cached github.com/google/pprof: commit='a8f279b7952b27edbcb72e5a6c69ee9be4c8ad93', urls=[https://github.com/google/pprof.git, git@github.com:google/pprof.git]
Resolving cached github.com/googleapis/gax-go: commit='bd5b16380fd03dc758d11cef74ba2e3bc8b0e8c2', urls=[https://github.com/googleapis/gax-go.git, git@github.com:googleapis/gax-go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/hashicorp/hcl: commit='23c074d0eceb2b8a5bfdbb271ab780cde70f05a8', urls=[https://github.com/hashicorp/hcl.git, git@github.com:hashicorp/hcl.git]
Resolving cached github.com/ianlancetaylor/demangle: commit='4883227f66371e02c4948937d3e2be1664d9be38', urls=[https://github.com/ianlancetaylor/demangle.git, git@github.com:ianlancetaylor/demangle.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/kr/fs: commit='2788f0dbd16903de03cb8186e5c7d97b69ad387b', urls=[https://github.com/kr/fs.git, git@github.com:kr/fs.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/linkedin/goavro: commit='94a7a9db615f35a39dd2b82089398b92fabad2ba', urls=[https://github.com/linkedin/goavro.git, git@github.com:linkedin/goavro.git]
Resolving cached github.com/magiconair/properties: commit='49d762b9817ba1c2e9d0c69183c2b4a8b8f1d934', urls=[https://github.com/magiconair/properties.git, git@github.com:magiconair/properties.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/mitchellh/go-homedir: commit='b8bc1bf767474819792c23f32d8286a45736f1c6', urls=[https://github.com/mitchellh/go-homedir.git, git@github.com:mitchellh/go-homedir.git]
Resolving cached github.com/mitchellh/mapstructure: commit='a4e142e9c047c904fa2f1e144d9a84e6133024bc', urls=[https://github.com/mitchellh/mapstructure.git, git@github.com:mitchellh/mapstructure.git]
Resolving cached github.com/nightlyone/lockfile: commit='0ad87eef1443f64d3d8c50da647e2b1552851124', urls=[https://github.com/nightlyone/lockfile, git@github.com:nightlyone/lockfile.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/openzipkin/zipkin-go: commit='3741243b287094fda649c7f0fa74bd51f37dc122', urls=[https://github.com/openzipkin/zipkin-go.git, git@github.com:openzipkin/zipkin-go.git]
Resolving cached github.com/pelletier/go-toml: commit='acdc4509485b587f5e675510c4f2c63e90ff68a8', urls=[https://github.com/pelletier/go-toml.git, git@github.com:pelletier/go-toml.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/pierrec/lz4: commit='ed8d4cc3b461464e69798080a0092bd028910298', urls=[https://github.com/pierrec/lz4.git, git@github.com:pierrec/lz4.git]
Resolving cached github.com/pierrec/xxHash: commit='a0006b13c722f7f12368c00a3d3c2ae8a999a0c6', urls=[https://github.com/pierrec/xxHash.git, git@github.com:pierrec/xxHash.git]
Resolving cached github.com/pkg/errors: commit='30136e27e2ac8d167177e8a583aa4c3fea5be833', urls=[https://github.com/pkg/errors.git, git@github.com:pkg/errors.git]
Resolving cached github.com/pkg/sftp: commit='22e9c1ccc02fc1b9fa3264572e49109b68a86947', urls=[https://github.com/pkg/sftp.git, git@github.com:pkg/sftp.git]
Resolving cached github.com/prometheus/client_golang: commit='9bb6ab929dcbe1c8393cd9ef70387cb69811bd1c', urls=[https://github.com/prometheus/client_golang.git, git@github.com:prometheus/client_golang.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/prometheus/procfs: commit='cb4147076ac75738c9a7d279075a253c0cc5acbd', urls=[https://github.com/prometheus/procfs.git, git@github.com:prometheus/procfs.git]
Resolving cached github.com/rcrowley/go-metrics: commit='8732c616f52954686704c8645fe1a9d59e9df7c1', urls=[https://github.com/rcrowley/go-metrics.git, git@github.com:rcrowley/go-metrics.git]
Resolving github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/afero: commit='bb8f1927f2a9d3ab41c9340aa034f6b803f4359c', urls=[https://github.com/spf13/afero.git, git@github.com:spf13/afero.git]
Resolving cached github.com/spf13/cast: commit='acbeb36b902d72a7a4c18e8f3241075e7ab763e4', urls=[https://github.com/spf13/cast.git, git@github.com:spf13/cast.git]
Resolving cached github.com/spf13/cobra: commit='93959269ad99e80983c9ba742a7e01203a4c0e4f', urls=[https://github.com/spf13/cobra.git, git@github.com:spf13/cobra.git]
Resolving cached github.com/spf13/jwalterweatherman: commit='7c0cea34c8ece3fbeb2b27ab9b59511d360fb394', urls=[https://github.com/spf13/jwalterweatherman.git, git@github.com:spf13/jwalterweatherman.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/viper: commit='aafc9e6bc7b7bb53ddaa75a5ef49a17d6e654be5', urls=[https://github.com/spf13/viper.git, git@github.com:spf13/viper.git]
Resolving cached github.com/stathat/go: commit='74669b9f388d9d788c97399a0824adbfee78400e', urls=[https://github.com/stathat/go.git, git@github.com:stathat/go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/xordataexchange/crypt: commit='b2862e3d0a775f18c7cfe02273500ae307b61218', urls=[https://github.com/xordataexchange/crypt.git, git@github.com:xordataexchange/crypt.git]
Resolving cached go.opencensus.io: commit='3fb168f674736c026e623310bfccb0691e6dec8a', urls=[https://github.com/census-instrumentation/opencensus-go]
Resolving cached golang.org/x/crypto: commit='d9133f5469342136e669e85192a26056b587f503', urls=[https://go.googlesource.com/crypto]
Resolving cached golang.org/x/debug: commit='95515998a8a4bd7448134b2cb5971dbeb12e0b77', urls=[https://go.googlesource.com/debug]
Resolving cached golang.org/x/net: commit='2fb46b16b8dda405028c50f7c7f0f9dd1fa6bfb1', urls=[https://go.googlesource.com/net]
Resolving cached golang.org/x/oauth2: commit='5d25da1a8d43b66f2898c444f899c7bcfd6a407e', urls=[https://go.googlesource.com/oauth2]
Resolving cached golang.org/x/sync: commit='fd80eb99c8f653c847d294a001bdf2a3a6f768f5', urls=[https://go.googlesource.com/sync]
Resolving cached golang.org/x/sys: commit='fde4db37ae7ad8191b03d30d27f258b5291ae4e3', urls=[https://go.googlesource.com/sys]
Resolving cached golang.org/x/text: commit='23ae387dee1f90d29a23c0e87ee0b46038fbed0e', urls=[https://go.googlesource.com/text]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached google.golang.org/api: commit='0324d5e90dc7753607860272666845fad9ceb97e', urls=[https://code.googlesource.com/google-api-go-client]
Resolving cached google.golang.org/genproto: commit='4d944d34d83c502a5f761500a14d8842648415c3', urls=[https://github.com/google/go-genproto]
Resolving cached google.golang.org/grpc: commit='5e8f83304c0563d1ba74db05fee83d9c18ab9a58', urls=[https://github.com/grpc/grpc-go]
Resolving cached google.golang.org/protobuf: commit='d165be301fb1e13390ad453281ded24385fd8ebc', urls=[https://go.googlesource.com/protobuf]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]

> Task :sdks:go:installDependencies
> Task :sdks:go:buildLinuxAmd64
> Task :sdks:go:goBuild

> Task :sdks:go:container:resolveBuildDependencies
Unable to watch the file system for changes. The inotify watches limit is too low.
Resolving ./github.com/apache/beam/sdks/go@<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go>

> Task :sdks:go:container:installDependencies
> Task :sdks:go:container:buildLinuxAmd64 UP-TO-DATE
> Task :sdks:go:container:goBuild
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD SUCCESSFUL in 1m 59s
14 actionable tasks: 12 executed, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

Publishing build scan...
https://gradle.com/s/5g4vg7yktsglm


ARGS="$ARGS --timeout=$TIMEOUT"
ARGS="$ARGS --runner=$RUNNER"
ARGS="$ARGS --project=$DATAFLOW_PROJECT"
ARGS="$ARGS --region=$REGION"
ARGS="$ARGS --environment_type=DOCKER"
ARGS="$ARGS --environment_config=$CONTAINER:$TAG"
ARGS="$ARGS --staging_location=$GCS_LOCATION/staging-validatesrunner-test"
ARGS="$ARGS --temp_location=$GCS_LOCATION/temp-validatesrunner-test"
ARGS="$ARGS --dataflow_worker_jar=$DATAFLOW_WORKER_JAR"
ARGS="$ARGS --endpoint=$ENDPOINT"
if [[ -n "$EXPANSION_ADDR" ]]; then
  ARGS="$ARGS --expansion_addr=$EXPANSION_ADDR"
fi

# Running "go test" requires some additional setup on Jenkins.
if [[ "$JENKINS" == true ]]; then
  # Copy the go repo as it is on Jenkins, to ensure we compile with the code
  # being tested.
  cd ..
  mkdir -p temp_gopath/src/github.com/apache/beam/sdks
  cp -a ./src/sdks/go ./temp_gopath/src/github.com/apache/beam/sdks
  TEMP_GOPATH=$(pwd)/temp_gopath
  cd ./src
>>> RUNNING flink VALIDATESRUNNER TESTS

  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  GOPATH=$TEMP_GOPATH go test -v github.com/apache/beam/sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
else
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  go test -v ./sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
fi
sdks/go/test/integration/integration.go:41:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/ptest" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOPATH)
sdks/go/test/integration/driver/driver.go:26:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOPATH)
sdks/go/test/integration/driver/driver.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOPATH)
sdks/go/test/integration/driver/driver.go:28:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/log" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOPATH)
sdks/go/test/integration/driver/driver.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/x/beamx" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOPATH)
sdks/go/test/integration/driver/driver.go:30:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/primitives" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOPATH)
sdks/go/test/integration/driver/driver.go:31:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOPATH)
sdks/go/test/integration/driver/driver.go:32:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/wordcount" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOPATH)
sdks/go/test/integration/primitives/cogbk.go:22:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/passert" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOPATH)
sdks/go/test/integration/synthetic/synthetic.go:21:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/textio" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/transforms/stats" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOPATH)

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 12m 15s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

Publishing build scan...
https://gradle.com/s/2qvawygjzbzbw

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4575

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

Changes:

[Ismaël Mejía] [BEAM-11213] Display Beam Metrics in Spark History Server for Classic

[Boyuan Zhang] Re-enable CrossLanguageKafkaIOTest

[noreply] [BEAM-11747] Narrow list of unsupported types in BeamJavaUdfCalcRule.

[noreply] [BEAM-12079] Enforce callable destination arg type for WriteToBigQuery

[Ismaël Mejía] [BEAM-12088] Make file staging uniform among Spark Runners


------------------------------------------
Started by timer
Running as SYSTEM
[EnvInject] - Loading node environment variables.
Building remotely on apache-beam-jenkins-7 (beam) in workspace <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/>
The recommended git tool is: NONE
No credentials specified
Wiping out workspace first.
Cloning the remote Git repository
Cloning repository https://github.com/apache/beam.git
 > git init <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src> # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git --version # timeout=10
 > git --version # 'git version 2.7.4'
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/beam.git # timeout=10
Fetching upstream changes from https://github.com/apache/beam.git
 > git fetch --tags --progress https://github.com/apache/beam.git +refs/heads/*:refs/remotes/origin/* +refs/pull/${ghprbPullId}/*:refs/remotes/origin/pr/${ghprbPullId}/* # timeout=10
 > git rev-parse origin/master^{commit} # timeout=10
Checking out Revision 5f13eff4f6cd6c45f40f1de9213a155471ede416 (origin/master)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5f13eff4f6cd6c45f40f1de9213a155471ede416 # timeout=10
Commit message: "Merge pull request #14417: [BEAM-12088] Make file staging uniform among Spark Runners"
 > git rev-list --no-walk 2c619c81082839e054f16efee9311b9f74b6e436 # timeout=10
No emails were triggered.
[EnvInject] - Executing scripts and injecting environment variables after the SCM step.
[EnvInject] - Injecting as environment variables the properties content 
SPARK_LOCAL_IP=127.0.0.1
SETUPTOOLS_USE_DISTUTILS=stdlib

[EnvInject] - Variables injected successfully.
[Gradle] - Launching build.
[src] $ <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/gradlew> -Pjenkins --continue --max-workers=12 -Dorg.gradle.jvmargs=-Xms2g -Dorg.gradle.jvmargs=-Xmx4g -Pdocker-pull-licenses :sdks:go:test:flinkValidatesRunner
> Task :buildSrc:compileJava NO-SOURCE
> Task :buildSrc:compileGroovy FROM-CACHE
> Task :buildSrc:pluginDescriptors
> Task :buildSrc:processResources
> Task :buildSrc:classes
> Task :buildSrc:jar
> Task :buildSrc:assemble
> Task :buildSrc:spotlessGroovy FROM-CACHE
> Task :buildSrc:spotlessGroovyCheck UP-TO-DATE
> Task :buildSrc:spotlessGroovyGradle FROM-CACHE
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins FROM-CACHE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build
Configuration on demand is an incubating feature.

> Configure project :runners:google-cloud-dataflow-java:worker
Unable to determine Checker Framework version. Assuming default is being used: 3.10.0

FAILURE: Build failed with an exception.

* Where:
Build file '<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/runners/google-cloud-dataflow-java/worker/build.gradle'> line: 29

* What went wrong:
A problem occurred evaluating project ':runners:google-cloud-dataflow-java:worker'.
> No such property: isCIBuild for class: java.lang.String

* 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 6s

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4574

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

Changes:

[noreply] [BEAM-7372] delete codes for compatibility of py2 from apache_beam/io


------------------------------------------
[...truncated 87.00 KB...]
> Task :buildSrc:spotlessGroovyGradleCheck UP-TO-DATE
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
Configuration on demand is an incubating feature.

> Task :sdks:go:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/.gogradle/project_gopath>

> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean

> Task :sdks:go:container:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/container/.gogradle/project_gopath>

> Task :sdks:go:resolveBuildDependencies
Unable to watch the file system for changes. The inotify watches limit is too low.
Resolving cached cloud.google.com/go: commit='03869a08dc16b35ad4968e92d34c5a2a2961b205', urls=[https://code.googlesource.com/gocloud]
Resolving cached github.com/Shopify/sarama: commit='541689b9f4212043471eb537fa72da507025d3ea', urls=[https://github.com/Shopify/sarama.git, git@github.com:Shopify/sarama.git]
Resolving cached github.com/armon/consul-api: commit='eb2c6b5be1b66bab83016e0b05f01b8d5496ffbd', urls=[https://github.com/armon/consul-api.git, git@github.com:armon/consul-api.git]
Resolving github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/davecgh/go-spew: commit='87df7c60d5820d0f8ae11afede5aa52325c09717', urls=[https://github.com/davecgh/go-spew.git, git@github.com:davecgh/go-spew.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/eapache/go-resiliency: commit='ef9aaa7ea8bd2448429af1a77cf41b2b3b34bdd6', urls=[https://github.com/eapache/go-resiliency.git, git@github.com:eapache/go-resiliency.git]
Resolving cached github.com/eapache/go-xerial-snappy: commit='bb955e01b9346ac19dc29eb16586c90ded99a98c', urls=[https://github.com/eapache/go-xerial-snappy.git, git@github.com:eapache/go-xerial-snappy.git]
Resolving cached github.com/eapache/queue: commit='44cc805cf13205b55f69e14bcb69867d1ae92f98', urls=[https://github.com/eapache/queue.git, git@github.com:eapache/queue.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/fsnotify/fsnotify: commit='c2828203cd70a50dcccfb2761f8b1f8ceef9a8e9', urls=[https://github.com/fsnotify/fsnotify.git, git@github.com:fsnotify/fsnotify.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/glog: commit='23def4e6c14b4da8ac2ed8007337bc5eb5007998', urls=[https://github.com/golang/glog.git, git@github.com:golang/glog.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/mock: commit='b3e60bcdc577185fce3cf625fc96b62857ce5574', urls=[https://github.com/golang/mock.git, git@github.com:golang/mock.git]
Resolving cached github.com/golang/protobuf: commit='d04d7b157bb510b1e0c10132224b616ac0e26b17', urls=[https://github.com/golang/protobuf.git, git@github.com:golang/protobuf.git]
Resolving cached github.com/golang/snappy: commit='553a641470496b2327abcac10b36396bd98e45c9', urls=[https://github.com/golang/snappy.git, git@github.com:golang/snappy.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/google/go-cmp: commit='9680bfaf28748393e28e00238d94070fb9972fd8', urls=[https://github.com/google/go-cmp.git, git@github.com:google/go-cmp.git]
Resolving cached github.com/google/pprof: commit='a8f279b7952b27edbcb72e5a6c69ee9be4c8ad93', urls=[https://github.com/google/pprof.git, git@github.com:google/pprof.git]
Resolving cached github.com/googleapis/gax-go: commit='bd5b16380fd03dc758d11cef74ba2e3bc8b0e8c2', urls=[https://github.com/googleapis/gax-go.git, git@github.com:googleapis/gax-go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/hashicorp/hcl: commit='23c074d0eceb2b8a5bfdbb271ab780cde70f05a8', urls=[https://github.com/hashicorp/hcl.git, git@github.com:hashicorp/hcl.git]
Resolving cached github.com/ianlancetaylor/demangle: commit='4883227f66371e02c4948937d3e2be1664d9be38', urls=[https://github.com/ianlancetaylor/demangle.git, git@github.com:ianlancetaylor/demangle.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/kr/fs: commit='2788f0dbd16903de03cb8186e5c7d97b69ad387b', urls=[https://github.com/kr/fs.git, git@github.com:kr/fs.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/linkedin/goavro: commit='94a7a9db615f35a39dd2b82089398b92fabad2ba', urls=[https://github.com/linkedin/goavro.git, git@github.com:linkedin/goavro.git]
Resolving cached github.com/magiconair/properties: commit='49d762b9817ba1c2e9d0c69183c2b4a8b8f1d934', urls=[https://github.com/magiconair/properties.git, git@github.com:magiconair/properties.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/mitchellh/go-homedir: commit='b8bc1bf767474819792c23f32d8286a45736f1c6', urls=[https://github.com/mitchellh/go-homedir.git, git@github.com:mitchellh/go-homedir.git]
Resolving cached github.com/mitchellh/mapstructure: commit='a4e142e9c047c904fa2f1e144d9a84e6133024bc', urls=[https://github.com/mitchellh/mapstructure.git, git@github.com:mitchellh/mapstructure.git]
Resolving cached github.com/nightlyone/lockfile: commit='0ad87eef1443f64d3d8c50da647e2b1552851124', urls=[https://github.com/nightlyone/lockfile, git@github.com:nightlyone/lockfile.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/openzipkin/zipkin-go: commit='3741243b287094fda649c7f0fa74bd51f37dc122', urls=[https://github.com/openzipkin/zipkin-go.git, git@github.com:openzipkin/zipkin-go.git]
Resolving cached github.com/pelletier/go-toml: commit='acdc4509485b587f5e675510c4f2c63e90ff68a8', urls=[https://github.com/pelletier/go-toml.git, git@github.com:pelletier/go-toml.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/pierrec/lz4: commit='ed8d4cc3b461464e69798080a0092bd028910298', urls=[https://github.com/pierrec/lz4.git, git@github.com:pierrec/lz4.git]
Resolving cached github.com/pierrec/xxHash: commit='a0006b13c722f7f12368c00a3d3c2ae8a999a0c6', urls=[https://github.com/pierrec/xxHash.git, git@github.com:pierrec/xxHash.git]
Resolving cached github.com/pkg/errors: commit='30136e27e2ac8d167177e8a583aa4c3fea5be833', urls=[https://github.com/pkg/errors.git, git@github.com:pkg/errors.git]
Resolving cached github.com/pkg/sftp: commit='22e9c1ccc02fc1b9fa3264572e49109b68a86947', urls=[https://github.com/pkg/sftp.git, git@github.com:pkg/sftp.git]
Resolving cached github.com/prometheus/client_golang: commit='9bb6ab929dcbe1c8393cd9ef70387cb69811bd1c', urls=[https://github.com/prometheus/client_golang.git, git@github.com:prometheus/client_golang.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/prometheus/procfs: commit='cb4147076ac75738c9a7d279075a253c0cc5acbd', urls=[https://github.com/prometheus/procfs.git, git@github.com:prometheus/procfs.git]
Resolving cached github.com/rcrowley/go-metrics: commit='8732c616f52954686704c8645fe1a9d59e9df7c1', urls=[https://github.com/rcrowley/go-metrics.git, git@github.com:rcrowley/go-metrics.git]
Resolving github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/afero: commit='bb8f1927f2a9d3ab41c9340aa034f6b803f4359c', urls=[https://github.com/spf13/afero.git, git@github.com:spf13/afero.git]
Resolving cached github.com/spf13/cast: commit='acbeb36b902d72a7a4c18e8f3241075e7ab763e4', urls=[https://github.com/spf13/cast.git, git@github.com:spf13/cast.git]
Resolving cached github.com/spf13/cobra: commit='93959269ad99e80983c9ba742a7e01203a4c0e4f', urls=[https://github.com/spf13/cobra.git, git@github.com:spf13/cobra.git]
Resolving cached github.com/spf13/jwalterweatherman: commit='7c0cea34c8ece3fbeb2b27ab9b59511d360fb394', urls=[https://github.com/spf13/jwalterweatherman.git, git@github.com:spf13/jwalterweatherman.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/viper: commit='aafc9e6bc7b7bb53ddaa75a5ef49a17d6e654be5', urls=[https://github.com/spf13/viper.git, git@github.com:spf13/viper.git]
Resolving cached github.com/stathat/go: commit='74669b9f388d9d788c97399a0824adbfee78400e', urls=[https://github.com/stathat/go.git, git@github.com:stathat/go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/xordataexchange/crypt: commit='b2862e3d0a775f18c7cfe02273500ae307b61218', urls=[https://github.com/xordataexchange/crypt.git, git@github.com:xordataexchange/crypt.git]
Resolving cached go.opencensus.io: commit='3fb168f674736c026e623310bfccb0691e6dec8a', urls=[https://github.com/census-instrumentation/opencensus-go]
Resolving cached golang.org/x/crypto: commit='d9133f5469342136e669e85192a26056b587f503', urls=[https://go.googlesource.com/crypto]
Resolving cached golang.org/x/debug: commit='95515998a8a4bd7448134b2cb5971dbeb12e0b77', urls=[https://go.googlesource.com/debug]
Resolving cached golang.org/x/net: commit='2fb46b16b8dda405028c50f7c7f0f9dd1fa6bfb1', urls=[https://go.googlesource.com/net]
Resolving cached golang.org/x/oauth2: commit='5d25da1a8d43b66f2898c444f899c7bcfd6a407e', urls=[https://go.googlesource.com/oauth2]
Resolving cached golang.org/x/sync: commit='fd80eb99c8f653c847d294a001bdf2a3a6f768f5', urls=[https://go.googlesource.com/sync]
Resolving cached golang.org/x/sys: commit='fde4db37ae7ad8191b03d30d27f258b5291ae4e3', urls=[https://go.googlesource.com/sys]
Resolving cached golang.org/x/text: commit='23ae387dee1f90d29a23c0e87ee0b46038fbed0e', urls=[https://go.googlesource.com/text]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached google.golang.org/api: commit='0324d5e90dc7753607860272666845fad9ceb97e', urls=[https://code.googlesource.com/google-api-go-client]
Resolving cached google.golang.org/genproto: commit='4d944d34d83c502a5f761500a14d8842648415c3', urls=[https://github.com/google/go-genproto]
Resolving cached google.golang.org/grpc: commit='5e8f83304c0563d1ba74db05fee83d9c18ab9a58', urls=[https://github.com/grpc/grpc-go]
Resolving cached google.golang.org/protobuf: commit='d165be301fb1e13390ad453281ded24385fd8ebc', urls=[https://go.googlesource.com/protobuf]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]

> Task :sdks:go:installDependencies
> Task :sdks:go:buildLinuxAmd64
> Task :sdks:go:goBuild

> Task :sdks:go:container:resolveBuildDependencies
Resolving ./github.com/apache/beam/sdks/go@<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go>

> Task :sdks:go:container:installDependencies
> Task :sdks:go:container:buildLinuxAmd64 UP-TO-DATE
> Task :sdks:go:container:goBuild
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD SUCCESSFUL in 1m 36s
14 actionable tasks: 12 executed, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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


ARGS="$ARGS --timeout=$TIMEOUT"
ARGS="$ARGS --runner=$RUNNER"
ARGS="$ARGS --project=$DATAFLOW_PROJECT"
ARGS="$ARGS --region=$REGION"
ARGS="$ARGS --environment_type=DOCKER"
ARGS="$ARGS --environment_config=$CONTAINER:$TAG"
ARGS="$ARGS --staging_location=$GCS_LOCATION/staging-validatesrunner-test"
ARGS="$ARGS --temp_location=$GCS_LOCATION/temp-validatesrunner-test"
ARGS="$ARGS --dataflow_worker_jar=$DATAFLOW_WORKER_JAR"
ARGS="$ARGS --endpoint=$ENDPOINT"
if [[ -n "$EXPANSION_ADDR" ]]; then
  ARGS="$ARGS --expansion_addr=$EXPANSION_ADDR"
fi

# Running "go test" requires some additional setup on Jenkins.
if [[ "$JENKINS" == true ]]; then
  # Copy the go repo as it is on Jenkins, to ensure we compile with the code
  # being tested.
  cd ..
  mkdir -p temp_gopath/src/github.com/apache/beam/sdks
  cp -a ./src/sdks/go ./temp_gopath/src/github.com/apache/beam/sdks
  TEMP_GOPATH=$(pwd)/temp_gopath
  cd ./src

  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  GOPATH=$TEMP_GOPATH go test -v github.com/apache/beam/sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
else
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  go test -v ./sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
fi
>>> RUNNING flink VALIDATESRUNNER TESTS
sdks/go/test/integration/integration.go:41:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/ptest" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOPATH)
sdks/go/test/integration/driver/driver.go:26:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOPATH)
sdks/go/test/integration/driver/driver.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOPATH)
sdks/go/test/integration/driver/driver.go:28:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/log" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOPATH)
sdks/go/test/integration/driver/driver.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/x/beamx" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOPATH)
sdks/go/test/integration/driver/driver.go:30:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/primitives" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOPATH)
sdks/go/test/integration/driver/driver.go:31:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOPATH)
sdks/go/test/integration/driver/driver.go:32:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/wordcount" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOPATH)
sdks/go/test/integration/primitives/cogbk.go:22:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/passert" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOPATH)
sdks/go/test/integration/synthetic/synthetic.go:21:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/textio" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/transforms/stats" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOPATH)

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 14m 5s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4573

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

Changes:

[noreply] Support multilayer ZetaSQL UNNEST (#14342)


------------------------------------------
[...truncated 93.20 KB...]
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
Configuration on demand is an incubating feature.

> Task :sdks:go:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/.gogradle/project_gopath>

> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean

> Task :sdks:go:container:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/container/.gogradle/project_gopath>

> Task :sdks:go:resolveBuildDependencies
Resolving cached cloud.google.com/go: commit='03869a08dc16b35ad4968e92d34c5a2a2961b205', urls=[https://code.googlesource.com/gocloud]
Resolving cached github.com/Shopify/sarama: commit='541689b9f4212043471eb537fa72da507025d3ea', urls=[https://github.com/Shopify/sarama.git, git@github.com:Shopify/sarama.git]
Resolving cached github.com/armon/consul-api: commit='eb2c6b5be1b66bab83016e0b05f01b8d5496ffbd', urls=[https://github.com/armon/consul-api.git, git@github.com:armon/consul-api.git]
Resolving github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/davecgh/go-spew: commit='87df7c60d5820d0f8ae11afede5aa52325c09717', urls=[https://github.com/davecgh/go-spew.git, git@github.com:davecgh/go-spew.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/eapache/go-resiliency: commit='ef9aaa7ea8bd2448429af1a77cf41b2b3b34bdd6', urls=[https://github.com/eapache/go-resiliency.git, git@github.com:eapache/go-resiliency.git]
Resolving cached github.com/eapache/go-xerial-snappy: commit='bb955e01b9346ac19dc29eb16586c90ded99a98c', urls=[https://github.com/eapache/go-xerial-snappy.git, git@github.com:eapache/go-xerial-snappy.git]
Resolving cached github.com/eapache/queue: commit='44cc805cf13205b55f69e14bcb69867d1ae92f98', urls=[https://github.com/eapache/queue.git, git@github.com:eapache/queue.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/fsnotify/fsnotify: commit='c2828203cd70a50dcccfb2761f8b1f8ceef9a8e9', urls=[https://github.com/fsnotify/fsnotify.git, git@github.com:fsnotify/fsnotify.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/glog: commit='23def4e6c14b4da8ac2ed8007337bc5eb5007998', urls=[https://github.com/golang/glog.git, git@github.com:golang/glog.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/mock: commit='b3e60bcdc577185fce3cf625fc96b62857ce5574', urls=[https://github.com/golang/mock.git, git@github.com:golang/mock.git]
Resolving cached github.com/golang/protobuf: commit='d04d7b157bb510b1e0c10132224b616ac0e26b17', urls=[https://github.com/golang/protobuf.git, git@github.com:golang/protobuf.git]
Resolving cached github.com/golang/snappy: commit='553a641470496b2327abcac10b36396bd98e45c9', urls=[https://github.com/golang/snappy.git, git@github.com:golang/snappy.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/google/go-cmp: commit='9680bfaf28748393e28e00238d94070fb9972fd8', urls=[https://github.com/google/go-cmp.git, git@github.com:google/go-cmp.git]
Resolving cached github.com/google/pprof: commit='a8f279b7952b27edbcb72e5a6c69ee9be4c8ad93', urls=[https://github.com/google/pprof.git, git@github.com:google/pprof.git]
Resolving cached github.com/googleapis/gax-go: commit='bd5b16380fd03dc758d11cef74ba2e3bc8b0e8c2', urls=[https://github.com/googleapis/gax-go.git, git@github.com:googleapis/gax-go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/hashicorp/hcl: commit='23c074d0eceb2b8a5bfdbb271ab780cde70f05a8', urls=[https://github.com/hashicorp/hcl.git, git@github.com:hashicorp/hcl.git]
Resolving cached github.com/ianlancetaylor/demangle: commit='4883227f66371e02c4948937d3e2be1664d9be38', urls=[https://github.com/ianlancetaylor/demangle.git, git@github.com:ianlancetaylor/demangle.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/kr/fs: commit='2788f0dbd16903de03cb8186e5c7d97b69ad387b', urls=[https://github.com/kr/fs.git, git@github.com:kr/fs.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/linkedin/goavro: commit='94a7a9db615f35a39dd2b82089398b92fabad2ba', urls=[https://github.com/linkedin/goavro.git, git@github.com:linkedin/goavro.git]
Resolving cached github.com/magiconair/properties: commit='49d762b9817ba1c2e9d0c69183c2b4a8b8f1d934', urls=[https://github.com/magiconair/properties.git, git@github.com:magiconair/properties.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/mitchellh/go-homedir: commit='b8bc1bf767474819792c23f32d8286a45736f1c6', urls=[https://github.com/mitchellh/go-homedir.git, git@github.com:mitchellh/go-homedir.git]
Resolving cached github.com/mitchellh/mapstructure: commit='a4e142e9c047c904fa2f1e144d9a84e6133024bc', urls=[https://github.com/mitchellh/mapstructure.git, git@github.com:mitchellh/mapstructure.git]
Resolving cached github.com/nightlyone/lockfile: commit='0ad87eef1443f64d3d8c50da647e2b1552851124', urls=[https://github.com/nightlyone/lockfile, git@github.com:nightlyone/lockfile.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/openzipkin/zipkin-go: commit='3741243b287094fda649c7f0fa74bd51f37dc122', urls=[https://github.com/openzipkin/zipkin-go.git, git@github.com:openzipkin/zipkin-go.git]
Resolving cached github.com/pelletier/go-toml: commit='acdc4509485b587f5e675510c4f2c63e90ff68a8', urls=[https://github.com/pelletier/go-toml.git, git@github.com:pelletier/go-toml.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/pierrec/lz4: commit='ed8d4cc3b461464e69798080a0092bd028910298', urls=[https://github.com/pierrec/lz4.git, git@github.com:pierrec/lz4.git]
Resolving cached github.com/pierrec/xxHash: commit='a0006b13c722f7f12368c00a3d3c2ae8a999a0c6', urls=[https://github.com/pierrec/xxHash.git, git@github.com:pierrec/xxHash.git]
Resolving cached github.com/pkg/errors: commit='30136e27e2ac8d167177e8a583aa4c3fea5be833', urls=[https://github.com/pkg/errors.git, git@github.com:pkg/errors.git]
Resolving cached github.com/pkg/sftp: commit='22e9c1ccc02fc1b9fa3264572e49109b68a86947', urls=[https://github.com/pkg/sftp.git, git@github.com:pkg/sftp.git]
Resolving cached github.com/prometheus/client_golang: commit='9bb6ab929dcbe1c8393cd9ef70387cb69811bd1c', urls=[https://github.com/prometheus/client_golang.git, git@github.com:prometheus/client_golang.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/prometheus/procfs: commit='cb4147076ac75738c9a7d279075a253c0cc5acbd', urls=[https://github.com/prometheus/procfs.git, git@github.com:prometheus/procfs.git]
Resolving cached github.com/rcrowley/go-metrics: commit='8732c616f52954686704c8645fe1a9d59e9df7c1', urls=[https://github.com/rcrowley/go-metrics.git, git@github.com:rcrowley/go-metrics.git]
Resolving github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/afero: commit='bb8f1927f2a9d3ab41c9340aa034f6b803f4359c', urls=[https://github.com/spf13/afero.git, git@github.com:spf13/afero.git]
Resolving cached github.com/spf13/cast: commit='acbeb36b902d72a7a4c18e8f3241075e7ab763e4', urls=[https://github.com/spf13/cast.git, git@github.com:spf13/cast.git]
Resolving cached github.com/spf13/cobra: commit='93959269ad99e80983c9ba742a7e01203a4c0e4f', urls=[https://github.com/spf13/cobra.git, git@github.com:spf13/cobra.git]
Resolving cached github.com/spf13/jwalterweatherman: commit='7c0cea34c8ece3fbeb2b27ab9b59511d360fb394', urls=[https://github.com/spf13/jwalterweatherman.git, git@github.com:spf13/jwalterweatherman.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/viper: commit='aafc9e6bc7b7bb53ddaa75a5ef49a17d6e654be5', urls=[https://github.com/spf13/viper.git, git@github.com:spf13/viper.git]
Resolving cached github.com/stathat/go: commit='74669b9f388d9d788c97399a0824adbfee78400e', urls=[https://github.com/stathat/go.git, git@github.com:stathat/go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/xordataexchange/crypt: commit='b2862e3d0a775f18c7cfe02273500ae307b61218', urls=[https://github.com/xordataexchange/crypt.git, git@github.com:xordataexchange/crypt.git]
Resolving cached go.opencensus.io: commit='3fb168f674736c026e623310bfccb0691e6dec8a', urls=[https://github.com/census-instrumentation/opencensus-go]
Resolving cached golang.org/x/crypto: commit='d9133f5469342136e669e85192a26056b587f503', urls=[https://go.googlesource.com/crypto]
Resolving cached golang.org/x/debug: commit='95515998a8a4bd7448134b2cb5971dbeb12e0b77', urls=[https://go.googlesource.com/debug]
Resolving cached golang.org/x/net: commit='2fb46b16b8dda405028c50f7c7f0f9dd1fa6bfb1', urls=[https://go.googlesource.com/net]
Resolving cached golang.org/x/oauth2: commit='5d25da1a8d43b66f2898c444f899c7bcfd6a407e', urls=[https://go.googlesource.com/oauth2]
Resolving cached golang.org/x/sync: commit='fd80eb99c8f653c847d294a001bdf2a3a6f768f5', urls=[https://go.googlesource.com/sync]
Resolving cached golang.org/x/sys: commit='fde4db37ae7ad8191b03d30d27f258b5291ae4e3', urls=[https://go.googlesource.com/sys]
Resolving cached golang.org/x/text: commit='23ae387dee1f90d29a23c0e87ee0b46038fbed0e', urls=[https://go.googlesource.com/text]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached google.golang.org/api: commit='0324d5e90dc7753607860272666845fad9ceb97e', urls=[https://code.googlesource.com/google-api-go-client]
Resolving cached google.golang.org/genproto: commit='4d944d34d83c502a5f761500a14d8842648415c3', urls=[https://github.com/google/go-genproto]
Resolving cached google.golang.org/grpc: commit='5e8f83304c0563d1ba74db05fee83d9c18ab9a58', urls=[https://github.com/grpc/grpc-go]
Resolving cached google.golang.org/protobuf: commit='d165be301fb1e13390ad453281ded24385fd8ebc', urls=[https://go.googlesource.com/protobuf]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]

> Task :sdks:go:installDependencies
> Task :sdks:go:buildLinuxAmd64
> Task :sdks:go:goBuild

> Task :sdks:go:container:resolveBuildDependencies
Unable to watch the file system for changes. The inotify watches limit is too low.
Resolving ./github.com/apache/beam/sdks/go@<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go>

> Task :sdks:go:container:installDependencies
> Task :sdks:go:container:buildLinuxAmd64
> Task :sdks:go:container:goBuild
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD SUCCESSFUL in 1m 5s
14 actionable tasks: 13 executed, 1 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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


ARGS="$ARGS --timeout=$TIMEOUT"
ARGS="$ARGS --runner=$RUNNER"
ARGS="$ARGS --project=$DATAFLOW_PROJECT"
ARGS="$ARGS --region=$REGION"
ARGS="$ARGS --environment_type=DOCKER"
>>> RUNNING flink VALIDATESRUNNER TESTS
ARGS="$ARGS --environment_config=$CONTAINER:$TAG"
ARGS="$ARGS --staging_location=$GCS_LOCATION/staging-validatesrunner-test"
ARGS="$ARGS --temp_location=$GCS_LOCATION/temp-validatesrunner-test"
ARGS="$ARGS --dataflow_worker_jar=$DATAFLOW_WORKER_JAR"
ARGS="$ARGS --endpoint=$ENDPOINT"
if [[ -n "$EXPANSION_ADDR" ]]; then
  ARGS="$ARGS --expansion_addr=$EXPANSION_ADDR"
fi

# Running "go test" requires some additional setup on Jenkins.
if [[ "$JENKINS" == true ]]; then
  # Copy the go repo as it is on Jenkins, to ensure we compile with the code
  # being tested.
  cd ..
  mkdir -p temp_gopath/src/github.com/apache/beam/sdks
  cp -a ./src/sdks/go ./temp_gopath/src/github.com/apache/beam/sdks
  TEMP_GOPATH=$(pwd)/temp_gopath
  cd ./src

  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  GOPATH=$TEMP_GOPATH go test -v github.com/apache/beam/sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
else
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  go test -v ./sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
fi
sdks/go/test/integration/integration.go:41:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/ptest" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOPATH)
sdks/go/test/integration/driver/driver.go:26:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOPATH)
sdks/go/test/integration/driver/driver.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOPATH)
sdks/go/test/integration/driver/driver.go:28:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/log" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOPATH)
sdks/go/test/integration/driver/driver.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/x/beamx" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOPATH)
sdks/go/test/integration/driver/driver.go:30:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/primitives" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOPATH)
sdks/go/test/integration/driver/driver.go:31:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOPATH)
sdks/go/test/integration/driver/driver.go:32:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/wordcount" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOPATH)
sdks/go/test/integration/primitives/cogbk.go:22:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/passert" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOPATH)
sdks/go/test/integration/synthetic/synthetic.go:21:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/textio" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/transforms/stats" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOPATH)

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 9m 10s
139 actionable tasks: 100 executed, 37 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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

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

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


Build failed in Jenkins: beam_PostCommit_Go_VR_Flink #4572

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

Changes:


------------------------------------------
[...truncated 87.25 KB...]
> Task :buildSrc:spotlessCheck UP-TO-DATE
> Task :buildSrc:pluginUnderTestMetadata UP-TO-DATE
> Task :buildSrc:compileTestJava NO-SOURCE
> Task :buildSrc:compileTestGroovy NO-SOURCE
> Task :buildSrc:processTestResources NO-SOURCE
> Task :buildSrc:testClasses UP-TO-DATE
> Task :buildSrc:test NO-SOURCE
> Task :buildSrc:validatePlugins UP-TO-DATE
> Task :buildSrc:check UP-TO-DATE
> Task :buildSrc:build UP-TO-DATE
Configuration on demand is an incubating feature.

> Task :sdks:go:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/.gogradle/project_gopath>

> Task :sdks:go:container:copyLicenses UP-TO-DATE
> Task :sdks:go:container:dockerClean

> Task :sdks:go:container:goPrepare
Use project GOPATH: <https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go/container/.gogradle/project_gopath>

> Task :sdks:go:resolveBuildDependencies
Resolving cached cloud.google.com/go: commit='03869a08dc16b35ad4968e92d34c5a2a2961b205', urls=[https://code.googlesource.com/gocloud]
Resolving cached github.com/Shopify/sarama: commit='541689b9f4212043471eb537fa72da507025d3ea', urls=[https://github.com/Shopify/sarama.git, git@github.com:Shopify/sarama.git]
Resolving cached github.com/armon/consul-api: commit='eb2c6b5be1b66bab83016e0b05f01b8d5496ffbd', urls=[https://github.com/armon/consul-api.git, git@github.com:armon/consul-api.git]
Resolving github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/davecgh/go-spew: commit='87df7c60d5820d0f8ae11afede5aa52325c09717', urls=[https://github.com/davecgh/go-spew.git, git@github.com:davecgh/go-spew.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/eapache/go-resiliency: commit='ef9aaa7ea8bd2448429af1a77cf41b2b3b34bdd6', urls=[https://github.com/eapache/go-resiliency.git, git@github.com:eapache/go-resiliency.git]
Resolving cached github.com/eapache/go-xerial-snappy: commit='bb955e01b9346ac19dc29eb16586c90ded99a98c', urls=[https://github.com/eapache/go-xerial-snappy.git, git@github.com:eapache/go-xerial-snappy.git]
Resolving cached github.com/eapache/queue: commit='44cc805cf13205b55f69e14bcb69867d1ae92f98', urls=[https://github.com/eapache/queue.git, git@github.com:eapache/queue.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/fsnotify/fsnotify: commit='c2828203cd70a50dcccfb2761f8b1f8ceef9a8e9', urls=[https://github.com/fsnotify/fsnotify.git, git@github.com:fsnotify/fsnotify.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/glog: commit='23def4e6c14b4da8ac2ed8007337bc5eb5007998', urls=[https://github.com/golang/glog.git, git@github.com:golang/glog.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/golang/mock: commit='b3e60bcdc577185fce3cf625fc96b62857ce5574', urls=[https://github.com/golang/mock.git, git@github.com:golang/mock.git]
Resolving cached github.com/golang/protobuf: commit='d04d7b157bb510b1e0c10132224b616ac0e26b17', urls=[https://github.com/golang/protobuf.git, git@github.com:golang/protobuf.git]
Resolving cached github.com/golang/snappy: commit='553a641470496b2327abcac10b36396bd98e45c9', urls=[https://github.com/golang/snappy.git, git@github.com:golang/snappy.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/google/go-cmp: commit='9680bfaf28748393e28e00238d94070fb9972fd8', urls=[https://github.com/google/go-cmp.git, git@github.com:google/go-cmp.git]
Resolving cached github.com/google/pprof: commit='a8f279b7952b27edbcb72e5a6c69ee9be4c8ad93', urls=[https://github.com/google/pprof.git, git@github.com:google/pprof.git]
Resolving cached github.com/googleapis/gax-go: commit='bd5b16380fd03dc758d11cef74ba2e3bc8b0e8c2', urls=[https://github.com/googleapis/gax-go.git, git@github.com:googleapis/gax-go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/hashicorp/hcl: commit='23c074d0eceb2b8a5bfdbb271ab780cde70f05a8', urls=[https://github.com/hashicorp/hcl.git, git@github.com:hashicorp/hcl.git]
Resolving cached github.com/ianlancetaylor/demangle: commit='4883227f66371e02c4948937d3e2be1664d9be38', urls=[https://github.com/ianlancetaylor/demangle.git, git@github.com:ianlancetaylor/demangle.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/kr/fs: commit='2788f0dbd16903de03cb8186e5c7d97b69ad387b', urls=[https://github.com/kr/fs.git, git@github.com:kr/fs.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/linkedin/goavro: commit='94a7a9db615f35a39dd2b82089398b92fabad2ba', urls=[https://github.com/linkedin/goavro.git, git@github.com:linkedin/goavro.git]
Resolving cached github.com/magiconair/properties: commit='49d762b9817ba1c2e9d0c69183c2b4a8b8f1d934', urls=[https://github.com/magiconair/properties.git, git@github.com:magiconair/properties.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/mitchellh/go-homedir: commit='b8bc1bf767474819792c23f32d8286a45736f1c6', urls=[https://github.com/mitchellh/go-homedir.git, git@github.com:mitchellh/go-homedir.git]
Resolving cached github.com/mitchellh/mapstructure: commit='a4e142e9c047c904fa2f1e144d9a84e6133024bc', urls=[https://github.com/mitchellh/mapstructure.git, git@github.com:mitchellh/mapstructure.git]
Resolving cached github.com/nightlyone/lockfile: commit='0ad87eef1443f64d3d8c50da647e2b1552851124', urls=[https://github.com/nightlyone/lockfile, git@github.com:nightlyone/lockfile.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/openzipkin/zipkin-go: commit='3741243b287094fda649c7f0fa74bd51f37dc122', urls=[https://github.com/openzipkin/zipkin-go.git, git@github.com:openzipkin/zipkin-go.git]
Resolving cached github.com/pelletier/go-toml: commit='acdc4509485b587f5e675510c4f2c63e90ff68a8', urls=[https://github.com/pelletier/go-toml.git, git@github.com:pelletier/go-toml.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/pierrec/lz4: commit='ed8d4cc3b461464e69798080a0092bd028910298', urls=[https://github.com/pierrec/lz4.git, git@github.com:pierrec/lz4.git]
Resolving cached github.com/pierrec/xxHash: commit='a0006b13c722f7f12368c00a3d3c2ae8a999a0c6', urls=[https://github.com/pierrec/xxHash.git, git@github.com:pierrec/xxHash.git]
Resolving cached github.com/pkg/errors: commit='30136e27e2ac8d167177e8a583aa4c3fea5be833', urls=[https://github.com/pkg/errors.git, git@github.com:pkg/errors.git]
Resolving cached github.com/pkg/sftp: commit='22e9c1ccc02fc1b9fa3264572e49109b68a86947', urls=[https://github.com/pkg/sftp.git, git@github.com:pkg/sftp.git]
Resolving cached github.com/prometheus/client_golang: commit='9bb6ab929dcbe1c8393cd9ef70387cb69811bd1c', urls=[https://github.com/prometheus/client_golang.git, git@github.com:prometheus/client_golang.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/prometheus/procfs: commit='cb4147076ac75738c9a7d279075a253c0cc5acbd', urls=[https://github.com/prometheus/procfs.git, git@github.com:prometheus/procfs.git]
Resolving cached github.com/rcrowley/go-metrics: commit='8732c616f52954686704c8645fe1a9d59e9df7c1', urls=[https://github.com/rcrowley/go-metrics.git, git@github.com:rcrowley/go-metrics.git]
Resolving github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/cpuguy83/go-md2man: commit='dc9f53734905c233adfc09fd4f063dce63ce3daf', urls=[https://github.com/cpuguy83/go-md2man.git, git@github.com:cpuguy83/go-md2man.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/afero: commit='bb8f1927f2a9d3ab41c9340aa034f6b803f4359c', urls=[https://github.com/spf13/afero.git, git@github.com:spf13/afero.git]
Resolving cached github.com/spf13/cast: commit='acbeb36b902d72a7a4c18e8f3241075e7ab763e4', urls=[https://github.com/spf13/cast.git, git@github.com:spf13/cast.git]
Resolving cached github.com/spf13/cobra: commit='93959269ad99e80983c9ba742a7e01203a4c0e4f', urls=[https://github.com/spf13/cobra.git, git@github.com:spf13/cobra.git]
Resolving cached github.com/spf13/jwalterweatherman: commit='7c0cea34c8ece3fbeb2b27ab9b59511d360fb394', urls=[https://github.com/spf13/jwalterweatherman.git, git@github.com:spf13/jwalterweatherman.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/spf13/viper: commit='aafc9e6bc7b7bb53ddaa75a5ef49a17d6e654be5', urls=[https://github.com/spf13/viper.git, git@github.com:spf13/viper.git]
Resolving cached github.com/stathat/go: commit='74669b9f388d9d788c97399a0824adbfee78400e', urls=[https://github.com/stathat/go.git, git@github.com:stathat/go.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/xordataexchange/crypt: commit='b2862e3d0a775f18c7cfe02273500ae307b61218', urls=[https://github.com/xordataexchange/crypt.git, git@github.com:xordataexchange/crypt.git]
Resolving cached go.opencensus.io: commit='3fb168f674736c026e623310bfccb0691e6dec8a', urls=[https://github.com/census-instrumentation/opencensus-go]
Resolving cached golang.org/x/crypto: commit='d9133f5469342136e669e85192a26056b587f503', urls=[https://go.googlesource.com/crypto]
Resolving cached golang.org/x/debug: commit='95515998a8a4bd7448134b2cb5971dbeb12e0b77', urls=[https://go.googlesource.com/debug]
Resolving cached golang.org/x/net: commit='2fb46b16b8dda405028c50f7c7f0f9dd1fa6bfb1', urls=[https://go.googlesource.com/net]
Resolving cached golang.org/x/oauth2: commit='5d25da1a8d43b66f2898c444f899c7bcfd6a407e', urls=[https://go.googlesource.com/oauth2]
Resolving cached golang.org/x/sync: commit='fd80eb99c8f653c847d294a001bdf2a3a6f768f5', urls=[https://go.googlesource.com/sync]
Resolving cached golang.org/x/sys: commit='fde4db37ae7ad8191b03d30d27f258b5291ae4e3', urls=[https://go.googlesource.com/sys]
Resolving cached golang.org/x/text: commit='23ae387dee1f90d29a23c0e87ee0b46038fbed0e', urls=[https://go.googlesource.com/text]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached google.golang.org/api: commit='0324d5e90dc7753607860272666845fad9ceb97e', urls=[https://code.googlesource.com/google-api-go-client]
Resolving cached google.golang.org/genproto: commit='4d944d34d83c502a5f761500a14d8842648415c3', urls=[https://github.com/google/go-genproto]
Resolving cached google.golang.org/grpc: commit='5e8f83304c0563d1ba74db05fee83d9c18ab9a58', urls=[https://github.com/grpc/grpc-go]
Resolving cached google.golang.org/protobuf: commit='d165be301fb1e13390ad453281ded24385fd8ebc', urls=[https://go.googlesource.com/protobuf]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]
Resolving cached github.com/etcd-io/etcd: commit='11214aa33bf5a47d3d9d8dafe0f6b97237dfe921', urls=[https://github.com/etcd-io/etcd.git, git@github.com:etcd-io/etcd.git]

> Task :sdks:go:installDependencies
> Task :sdks:go:buildLinuxAmd64
> Task :sdks:go:goBuild

> Task :sdks:go:container:resolveBuildDependencies
Unable to watch the file system for changes. The inotify watches limit is too low.
Resolving ./github.com/apache/beam/sdks/go@<https://ci-beam.apache.org/job/beam_PostCommit_Go_VR_Flink/ws/src/sdks/go>

> Task :sdks:go:container:installDependencies
> Task :sdks:go:container:buildLinuxAmd64 UP-TO-DATE
> Task :sdks:go:container:goBuild
> Task :sdks:go:container:dockerPrepare
> Task :sdks:go:container:docker

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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD SUCCESSFUL in 1m 27s
14 actionable tasks: 12 executed, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

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


ARGS="$ARGS --timeout=$TIMEOUT"
ARGS="$ARGS --runner=$RUNNER"
ARGS="$ARGS --project=$DATAFLOW_PROJECT"
ARGS="$ARGS --region=$REGION"
ARGS="$ARGS --environment_type=DOCKER"
ARGS="$ARGS --environment_config=$CONTAINER:$TAG"
ARGS="$ARGS --staging_location=$GCS_LOCATION/staging-validatesrunner-test"
ARGS="$ARGS --temp_location=$GCS_LOCATION/temp-validatesrunner-test"
ARGS="$ARGS --dataflow_worker_jar=$DATAFLOW_WORKER_JAR"
ARGS="$ARGS --endpoint=$ENDPOINT"
if [[ -n "$EXPANSION_ADDR" ]]; then
  ARGS="$ARGS --expansion_addr=$EXPANSION_ADDR"
fi

# Running "go test" requires some additional setup on Jenkins.
if [[ "$JENKINS" == true ]]; then
  # Copy the go repo as it is on Jenkins, to ensure we compile with the code
  # being tested.
  cd ..
  mkdir -p temp_gopath/src/github.com/apache/beam/sdks
  cp -a ./src/sdks/go ./temp_gopath/src/github.com/apache/beam/sdks
  TEMP_GOPATH=$(pwd)/temp_gopath
  cd ./src

>>> RUNNING flink VALIDATESRUNNER TESTS
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  GOPATH=$TEMP_GOPATH go test -v github.com/apache/beam/sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
else
  echo ">>> RUNNING $RUNNER VALIDATESRUNNER TESTS"
  go test -v ./sdks/go/test/integration/... $ARGS \
      || TEST_EXIT_CODE=$? # don't fail fast here; clean up environment before exiting
fi
sdks/go/test/integration/integration.go:41:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/ptest" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/ptest (from $GOPATH)
sdks/go/test/integration/driver/driver.go:26:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam (from $GOPATH)
sdks/go/test/integration/driver/driver.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/filesystem/memfs (from $GOPATH)
sdks/go/test/integration/driver/driver.go:28:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/log" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/log (from $GOPATH)
sdks/go/test/integration/driver/driver.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/x/beamx" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/x/beamx (from $GOPATH)
sdks/go/test/integration/driver/driver.go:30:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/primitives" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/primitives (from $GOPATH)
sdks/go/test/integration/driver/driver.go:31:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/synthetic (from $GOPATH)
sdks/go/test/integration/driver/driver.go:32:2: cannot find package "github.com/apache/beam/sdks/go/test/integration/wordcount" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/test/integration/wordcount (from $GOPATH)
sdks/go/test/integration/primitives/cogbk.go:22:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/testing/passert" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/testing/passert (from $GOPATH)
sdks/go/test/integration/synthetic/synthetic.go:21:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/synthetic" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/synthetic (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:27:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/io/textio" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/io/textio (from $GOPATH)
sdks/go/test/integration/wordcount/wordcount.go:29:2: cannot find package "github.com/apache/beam/sdks/go/pkg/beam/transforms/stats" in any of:
	/usr/lib/go-1.12/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOROOT)
	/home/jenkins/go/src/github.com/apache/beam/sdks/go/pkg/beam/transforms/stats (from $GOPATH)

if [[ "$RUNNER" == "dataflow" ]]; then
  # Delete the container locally and remotely
  docker rmi $CONTAINER:$TAG || echo "Failed to remove container"
  gcloud --quiet container images delete $CONTAINER:$TAG || echo "Failed to delete container"

  # Clean up tempdir
  rm -rf $TMPDIR
fi

exit $TEST_EXIT_CODE
exit_background_processes

> Task :sdks:go:test:flinkValidatesRunner FAILED

FAILURE: Build failed with an exception.

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

* What went wrong:
Execution failed for task ':sdks:go:test:flinkValidatesRunner'.
> Process 'command 'sh'' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. 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.8/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 8m 26s
139 actionable tasks: 96 executed, 41 from cache, 2 up-to-date
Gradle was unable to watch the file system for changes. The inotify watches limit is too low.

Publishing build scan...
https://gradle.com/s/54luah4p6dork

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