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

Build failed in Jenkins: beam_PreCommit_Python_Cron #2861

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

Changes:

[klk] Split Nexmark QueryTest and SqlQueryTest for clarity

[klk] Add ZetaSQL Nexmark variant

[annaqin] [BEAM-10225] Add log message when starting job server

[valentyn] [BEAM-10227] Switches typing version modifier to python_full_version so

[kamil.wasilewski] [BEAM-8134] Grafana dashboards for Nexmark tests


------------------------------------------
[...truncated 1.20 MB...]
    | beam.FlatMap(lambda x: x.read().decode('utf-8').splitlines()))

apache_beam/io/mongodbio_test.py:309
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/mongodbio_test.py>:309: FutureWarning: WriteToMongoDB is experimental.
    | "Write" >> WriteToMongoDB(db='test', coll='test'))

apache_beam/io/mongodbio_test.py:325
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/mongodbio_test.py>:325: FutureWarning: WriteToMongoDB is experimental.
    | "Write" >> WriteToMongoDB(db='test', coll='test'))

apache_beam/io/fileio_test.py:416
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:416: FutureWarning: WriteToFiles is experimental.
    max_writers_per_bundle=1))

apache_beam/io/fileio_test.py:424
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:424: FutureWarning: MatchFiles is experimental.
    | beam.Map(json.loads))

apache_beam/io/fileio_test.py:424
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:424: FutureWarning: ReadMatches is experimental.
    | beam.Map(json.loads))

apache_beam/io/fileio_test.py:431
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:431: FutureWarning: MatchFiles is experimental.
    | "MapApache" >>

apache_beam/io/fileio_test.py:431
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:431: FutureWarning: ReadMatches is experimental.
    | "MapApache" >>

apache_beam/io/fileio_test.py:78
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:78: FutureWarning: MatchFiles is experimental.
    | beam.Map(lambda x: x.path))

apache_beam/io/fileio_test.py:272
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:272: FutureWarning: ReadMatches is experimental.
    | beam.Map(lambda x: x.read_utf8()))

apache_beam/io/fileio_test.py:452
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:452: FutureWarning: WriteToFiles is experimental.
    write_transform = beam.io.fileio.WriteToFiles(path=dir)

apache_beam/io/parquetio_test.py:412
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/parquetio_test.py>:412: FutureWarning: The parameter chunksize is deprecated for pyarrow.Table.to_batches as of 0.15, please use the parameter max_chunksize instead
    for batch in orig.to_batches(chunksize=20)

apache_beam/io/parquetio_test.py:364
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/parquetio_test.py>:364: FutureWarning: The parameter chunksize is deprecated for pyarrow.Table.to_batches as of 0.15, please use the parameter max_chunksize instead
    count=12000).to_batches(chunksize=1000)

apache_beam/io/fileio_test.py:589
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:589: FutureWarning: WriteToFiles is experimental.
    | beam.ParDo(self.record_dofn()))

apache_beam/io/fileio_test.py:593
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:593: FutureWarning: MatchFiles is experimental.
    files = (p | beam.io.fileio.MatchFiles(FileSystems.join(dir, '*')))

apache_beam/io/fileio_test.py:600
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/fileio_test.py>:600: FutureWarning: ReadMatches is experimental.
    | beam.Map(

apache_beam/io/parquetio_test.py:374
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/io/parquetio_test.py>:374: FutureWarning: The parameter chunksize is deprecated for pyarrow.Table.to_batches as of 0.15, please use the parameter max_chunksize instead
    count=12000).to_batches(chunksize=1000)

apache_beam/runners/interactive/interactive_beam.py:388
apache_beam/runners/interactive/interactive_beam.py:388
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:388: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    runner, user_pipeline, user_pipeline.options)

apache_beam/runners/interactive/interactive_beam.py:411
apache_beam/runners/interactive/interactive_beam.py:411
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/runners/interactive/interactive_beam.py>:411: BeamDeprecationWarning: options is deprecated since First stable release. References to <pipeline>.options will not be supported
    result = pf.PipelineFragment(list(pcolls), user_pipeline.options).run()

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/hamcrest/library/collection/issequence_containinginorder.py:95
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/hamcrest/library/collection/issequence_containinginorder.py>:95: DeprecationWarning: deprecated - use contains_exactly(*items)
    warnings.warn("deprecated - use contains_exactly(*items)", DeprecationWarning)

apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
apache_beam/transforms/combiners.py:186
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:186: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/combiners.py:275
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/combiners.py>:275: DeprecationWarning: Compare not available in Python 3, use key instead.
    DeprecationWarning)

apache_beam/transforms/util_test.py:655
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/transforms/util_test.py>:655: FutureWarning: GroupIntoBatches is experimental.
    | util.GroupIntoBatches(GroupIntoBatchesTest.BATCH_SIZE)

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython.xml> -
=========== 2598 passed, 597 skipped, 76 warnings in 360.63 seconds ============
============================= test session starts ==============================
platform linux2 -- Python 2.7.12, pytest-4.6.11, py-1.8.1, pluggy-0.13.1
cachedir: target/.tox-py27-cython/py27-cython/.pytest_cache
rootdir: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python,> inifile: pytest.ini
plugins: requests-mock-1.8.0, xdist-1.32.0, forked-1.1.3, timeout-1.3.4
timeout: 600.0s
timeout method: signal
timeout func_only: False
collected 3252 items / 3194 deselected / 4 skipped / 54 selected

apache_beam/coders/fast_coders_test.py ............................      [ 48%]
apache_beam/coders/slow_coders_test.py ............................      [ 96%]
apache_beam/io/gcp/tests/bigquery_matcher_test.py s                      [ 98%]
apache_beam/runners/portability/stager_test.py .                         [100%]

=============================== warnings summary ===============================
apache_beam/__init__.py:82
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/apache_beam/__init__.py>:82: UserWarning: You are using Apache Beam with Python 2. New releases of Apache Beam will soon support Python 3 only.
    'You are using Apache Beam with Python 2. '

target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py:3
  <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/target/.tox-py27-cython/py27-cython/lib/python2.7/site-packages/py/_code/_assertionold.py>:3: DeprecationWarning: The compiler package is deprecated and removed in Python 3.x.
    from compiler import parse, ast, pycodegen

-- Docs: https://docs.pytest.org/en/latest/warnings.html
- generated xml file: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/pytest_py27-cython_no_xdist.xml> -
====== 57 passed, 5 skipped, 3194 deselected, 2 warnings in 8.23 seconds =======
py27-cython run-test-post: commands[0] | <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/test-suites/tox/py2/build/srcs/sdks/python/scripts/run_tox_cleanup.sh>
___________________________________ summary ____________________________________
  py27-cython: commands succeeded
  congratulations :)

> Task :sdks:python:test-suites:tox:py2:preCommitPy2

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
WARNING:apache_beam.runners.dataflow.dataflow_runner:Timing out on waiting for job 2020-06-10_11_42_30-16245644010893448657 after 360 seconds

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_streaming_V2
WARNING:apache_beam.runners.dataflow.dataflow_runner:Timing out on waiting for job 2020-06-10_11_42_28-781250988814917663 after 360 seconds
DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254
DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 192

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254
DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 192

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_streaming_V2
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ok

----------------------------------------------------------------------
XML: nosetests-preCommitIT-df-py27.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1 test in 546.806s

OK
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-10_11_42_28-781250988814917663?project=apache-beam-testing

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_V2

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-10_11_42_30-16245644010893448657?project=apache-beam-testing
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ok

----------------------------------------------------------------------
XML: nosetests-preCommitIT-df-py37.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1 test in 579.189s

OK

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_V2

FAILURE: Build completed with 5 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py35:testPy35Cloud'.
> 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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py37:testPy37Cloud'.
> 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py38:testPy38Cloud'.
> 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.
==============================================================================

4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:pycommon:docs'.
> 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.
==============================================================================

5: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py36:testPy36Cloud'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 39m 55s
89 actionable tasks: 71 executed, 18 from cache

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

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

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


Jenkins build is back to normal : beam_PreCommit_Python_Cron #2863

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


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


Build failed in Jenkins: beam_PreCommit_Python_Cron #2862

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PreCommit_Python_Cron/2862/display/redirect?page=changes>

Changes:

[robertwb] [BEAM-9577] Remove use of legacy artifact service in Python.

[robertwb] Simplify Python on Flink runner instructions.

[robertwb] Fix stray paragraph, separate and rework python.

[tysonjh] [BEAM-9999] Remove Gearpump runner.

[robertwb] Expand note on runner selection.

[amaliujia] [BEAM-10230] @Ignore: BYTES works with LIKE.

[robertwb] Move Beam Compatibility table below instructions.

[github] [BEAM-9742] Add Configurable FluentBackoff to JdbcIO Write (#11396)

[github] Finalize CHANGES.md for 2.22.0 (#11973)

[github] [BEAM-9679] Add CombinePerKey to Core Transforms Go Katas (#11936)


------------------------------------------
[...truncated 1.16 MB...]
          {
            "key": "fn",
            "label": "Transform Function",
            "namespace": "apache_beam.transforms.core.ParDo",
            "shortValue": "CallableWrapperDoFn",
            "type": "STRING",
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          },
          {
            "key": "fn",
            "label": "Transform Function",
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn",
            "type": "STRING",
            "value": "<lambda>"
          }
        ],
        "non_parallel_inputs": {},
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value",
              "component_encodings": [
                {
                  "@type": "kind:bytes"
                },
                {
                  "@type": "kind:interval_window"
                }
              ],
              "is_wrapper": true
            },
            "output_name": "None",
            "user_name": "encode.out"
          }
        ],
        "parallel_input": {
          "@type": "OutputReference",
          "output_name": "None",
          "step_name": "s8"
        },
        "serialized_fn": "ref_AppliedPTransform_encode_11",
        "user_name": "encode"
      }
    },
    {
      "kind": "ParallelWrite",
      "name": "s10",
      "properties": {
        "display_data": [],
        "encoding": {
          "@type": "kind:windowed_value",
          "component_encodings": [
            {
              "@type": "kind:bytes"
            },
            {
              "@type": "kind:global_window"
            }
          ],
          "is_wrapper": true
        },
        "format": "pubsub",
        "parallel_input": {
          "@type": "OutputReference",
          "output_name": "None",
          "step_name": "s9"
        },
        "pubsub_topic": "projects/apache-beam-testing/topics/wc_topic_output538ab762-5731-4f98-a32b-8eb35b52f047",
        "user_name": "WriteToPubSub/Write/NativeWrite"
      }
    }
  ],
  "type": "JOB_TYPE_STREAMING"
}
INFO:apache_beam.runners.dataflow.internal.apiclient:Create job: <Job
 createTime: '2020-06-11T00:45:57.299955Z'
 currentStateTime: '1970-01-01T00:00:00Z'
 id: '2020-06-10_17_45_56-3362912391846134571'
 location: 'us-central1'
 name: 'beamapp-jenkins-0611004547-325416'
 projectId: 'apache-beam-testing'
 stageStates: []
 startTime: '2020-06-11T00:45:57.299955Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_STREAMING, 2)>
INFO:apache_beam.runners.dataflow.internal.apiclient:Created job with id: [2020-06-10_17_45_56-3362912391846134571]
INFO:apache_beam.runners.dataflow.internal.apiclient:Submitted job: 2020-06-10_17_45_56-3362912391846134571
INFO:apache_beam.runners.dataflow.internal.apiclient:To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-10_17_45_56-3362912391846134571?project=apache-beam-testing

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_streaming_V2
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:45:37.384Z: JOB_MESSAGE_WARNING: Your project already contains 100 Dataflow-created metric descriptors and Stackdriver will not create new Dataflow custom metrics for this job. Each unique user-defined metric name (independent of the DoFn in which it is defined) produces a new metric descriptor. To delete old / unused metric descriptors see https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list and https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:45:40.416Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 so that the pipeline can catch up with its backlog and keep up with its input rate.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:15.858Z: JOB_MESSAGE_DETAILED: Workers have started successfully.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:15.889Z: JOB_MESSAGE_DETAILED: Workers have started successfully.

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
INFO:apache_beam.runners.dataflow.dataflow_runner:Job 2020-06-10_17_45_56-3362912391846134571 is in state JOB_STATE_RUNNING
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:45:56.125Z: JOB_MESSAGE_DETAILED: Autoscaling was automatically enabled for job 2020-06-10_17_45_56-3362912391846134571.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:45:56.125Z: JOB_MESSAGE_WARNING: Autoscaling is enabled for Dataflow Streaming Engine. Workers will scale between 1 and 100 unless maxNumWorkers is specified.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:45:56.125Z: JOB_MESSAGE_DETAILED: Autoscaling is enabled for job 2020-06-10_17_45_56-3362912391846134571. The number of workers will be between 1 and 100.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:02.694Z: JOB_MESSAGE_BASIC: Worker configuration: n1-standard-2 in us-central1-a.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.605Z: JOB_MESSAGE_DETAILED: Expanding SplittableParDo operations into optimizable parts.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.642Z: JOB_MESSAGE_DETAILED: Expanding CollectionToSingleton operations into optimizable parts.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.704Z: JOB_MESSAGE_DETAILED: Expanding CoGroupByKey operations into optimizable parts.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.757Z: JOB_MESSAGE_DEBUG: Combiner lifting skipped for step group: GroupByKey not followed by a combiner.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.813Z: JOB_MESSAGE_DETAILED: Expanding SplittableProcessKeyed operations into optimizable parts.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.850Z: JOB_MESSAGE_DETAILED: Expanding GroupByKey operations into streaming Read/Write steps
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:03.924Z: JOB_MESSAGE_DETAILED: Lifting ValueCombiningMappingFns into MergeBucketsMappingFns
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.006Z: JOB_MESSAGE_DEBUG: Annotating graph with Autotuner information.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.063Z: JOB_MESSAGE_DETAILED: Fusing adjacent ParDo, Read, Write, and Flatten operations
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.099Z: JOB_MESSAGE_DETAILED: Fusing consumer decode into ReadFromPubSub/Read
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.137Z: JOB_MESSAGE_DETAILED: Fusing consumer split into decode
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.178Z: JOB_MESSAGE_DETAILED: Fusing consumer pair_with_one into split
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.211Z: JOB_MESSAGE_DETAILED: Fusing consumer WindowInto(WindowIntoFn) into pair_with_one
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.246Z: JOB_MESSAGE_DETAILED: Fusing consumer group/WriteStream into WindowInto(WindowIntoFn)
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.282Z: JOB_MESSAGE_DETAILED: Fusing consumer group/MergeBuckets into group/ReadStream
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.317Z: JOB_MESSAGE_DETAILED: Fusing consumer count into group/MergeBuckets
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.352Z: JOB_MESSAGE_DETAILED: Fusing consumer format into count
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.389Z: JOB_MESSAGE_DETAILED: Fusing consumer encode into format
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.429Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteToPubSub/Write/NativeWrite into encode
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.492Z: JOB_MESSAGE_DEBUG: Workflow config is missing a default resource spec.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.527Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.564Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:04.601Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:06.920Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:06.953Z: JOB_MESSAGE_BASIC: Starting 1 workers in us-central1-a...
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:06.990Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:13.151Z: JOB_MESSAGE_WARNING: Your project already contains 100 Dataflow-created metric descriptors and Stackdriver will not create new Dataflow custom metrics for this job. Each unique user-defined metric name (independent of the DoFn in which it is defined) produces a new metric descriptor. To delete old / unused metric descriptors see https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.list and https://developers.google.com/apis-explorer/#p/monitoring/v3/monitoring.projects.metricDescriptors.delete
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:46:38.643Z: JOB_MESSAGE_DETAILED: Autoscaling: Raised the number of workers to 1 so that the pipeline can catch up with its backlog and keep up with its input rate.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:47:17.656Z: JOB_MESSAGE_DETAILED: Workers have started successfully.
INFO:apache_beam.runners.dataflow.dataflow_runner:2020-06-11T00:47:17.701Z: JOB_MESSAGE_DETAILED: Workers have started successfully.

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_streaming_V2
WARNING:apache_beam.runners.dataflow.dataflow_runner:Timing out on waiting for job 2020-06-10_17_45_00-11323527088647662550 after 360 seconds
DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254
DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 192

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
WARNING:apache_beam.runners.dataflow.dataflow_runner:Timing out on waiting for job 2020-06-10_17_45_56-3362912391846134571 after 360 seconds
DEBUG:google.auth.transport._http_client:Making request: GET http://169.254.169.254
DEBUG:google.auth.transport._http_client:Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
DEBUG:urllib3.connectionpool:Starting new HTTP connection (1): metadata.google.internal:80
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
DEBUG:google.auth.transport.requests:Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
DEBUG:urllib3.connectionpool:http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 192

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_streaming_V2
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ok

----------------------------------------------------------------------
XML: nosetests-preCommitIT-df-py27.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1 test in 545.931s

OK
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-10_17_45_00-11323527088647662550?project=apache-beam-testing

> Task :sdks:python:test-suites:dataflow:py2:preCommitIT_V2

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_streaming_V2
Worker logs: https://console.cloud.google.com/dataflow/jobs/us-central1/2020-06-10_17_45_56-3362912391846134571?project=apache-beam-testing
test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT) ... ok

----------------------------------------------------------------------
XML: nosetests-preCommitIT-df-py37.xml
----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PreCommit_Python_Cron/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1 test in 546.822s

OK

> Task :sdks:python:test-suites:dataflow:py37:preCommitIT_V2

FAILURE: Build completed with 5 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py35:testPy35Cloud'.
> 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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py37:testPy37Cloud'.
> 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py38:testPy38Cloud'.
> 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.
==============================================================================

4: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:py36:testPy36Cloud'.
> 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.
==============================================================================

5: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':sdks:python:test-suites:tox:pycommon:docs'.
> 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 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 38m 36s
89 actionable tasks: 71 executed, 18 from cache

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

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

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