Skip to content

Update metrics to PEP 585 typing #7535

Update metrics to PEP 585 typing

Update metrics to PEP 585 typing #7535

GitHub Actions / Test Results failed Nov 14, 2024 in 0s

1 fail in 37m 58s

1 tests   0 ✅  37m 58s ⏱️
1 suites  0 💤
1 files    1 ❌

Results for commit df4f455.

Annotations

Check warning on line 0 in apache_beam.examples.wordcount_it_test.WordCountIT

See this annotation in the file changed.

@github-actions github-actions / Test Results

test_wordcount_it (apache_beam.examples.wordcount_it_test.WordCountIT) failed

sdks/python/pytest_preCommitIT-df-py39.xml [took 37m 55s]
Raw output
apitools.base.py.exceptions.InvalidUserInputError: Request missing required parameter jobId
args = (<apache_beam.runners.dataflow.internal.apiclient.DataflowApplicationClient object at 0x7a5394013b80>, None)
kwargs = {}
retry_intervals = <generator object FuzzedExponentialIntervals.__iter__ at 0x7a53941e1430>
exn_traceback = None, sleep_interval = 238.0620663703449

    @functools.wraps(fun)
    def wrapper(*args, **kwargs):
      retry_intervals = iter(
          FuzzedExponentialIntervals(
              initial_delay_secs,
              num_retries,
              factor,
              fuzz=0.5 if fuzz else 0,
              max_delay_secs=max_delay_secs,
              stop_after_secs=stop_after_secs))
      while True:
        try:
          return fun(*args, **kwargs)
        except Exception as exn:  # pylint: disable=broad-except
          if not retry_filter(exn):
            raise
          # Get the traceback object for the current exception. The
          # sys.exc_info() function returns a tuple with three elements:
          # exception type, exception value, and exception traceback.
          exn_traceback = sys.exc_info()[2]
          try:
            try:
>             sleep_interval = next(retry_intervals)
E             StopIteration

apache_beam/utils/retry.py:308: StopIteration

During handling of the above exception, another exception occurred:

self = <apache_beam.examples.wordcount_it_test.WordCountIT testMethod=test_wordcount_it>

    @pytest.mark.it_postcommit
    @pytest.mark.it_validatescontainer
    def test_wordcount_it(self):
>     self._run_wordcount_it(wordcount.run)

apache_beam/examples/wordcount_it_test.py:50: 
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 
apache_beam/examples/wordcount_it_test.py:150: in _run_wordcount_it
    run_wordcount(
apache_beam/examples/wordcount.py:106: in run
    output | 'Write' >> WriteToText(known_args.output)
apache_beam/pipeline.py:620: in __exit__
    self.result = self.run()
apache_beam/pipeline.py:567: in run
    return Pipeline.from_runner_api(
apache_beam/pipeline.py:594: in run
    return self.runner.run_pipeline(self, self._options)
apache_beam/runners/dataflow/test_dataflow_runner.py:74: in run_pipeline
    self.wait_until_in_state(PipelineState.CANCELLED)
apache_beam/runners/dataflow/test_dataflow_runner.py:98: in wait_until_in_state
    job_state = self.result.state
apache_beam/runners/dataflow/dataflow_runner.py:766: in state
    self._update_job()
apache_beam/runners/dataflow/dataflow_runner.py:708: in _update_job
    self._job = self._runner.dataflow_client.get_job(self.job_id())
apache_beam/utils/retry.py:311: in wrapper
    raise exn.with_traceback(exn_traceback)
apache_beam/utils/retry.py:298: in wrapper
    return fun(*args, **kwargs)
apache_beam/runners/dataflow/internal/apiclient.py:925: in get_job
    response = self._client.projects_locations_jobs.Get(request)
apache_beam/runners/dataflow/internal/clients/dataflow/dataflow_v1b3_client.py:743: in Get
    return self._RunMethod(config, request, global_params=global_params)
../../build/gradleenv/-1734967050/lib/python3.9/site-packages/apitools/base/py/base_api.py:701: in _RunMethod
    http_request = self.PrepareHttpRequest(
../../build/gradleenv/-1734967050/lib/python3.9/site-packages/apitools/base/py/base_api.py:683: in PrepareHttpRequest
    url_builder.relative_path = self.__ConstructRelativePath(
../../build/gradleenv/-1734967050/lib/python3.9/site-packages/apitools/base/py/base_api.py:583: in __ConstructRelativePath
    return util.ExpandRelativePath(method_config, params,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ 

method_config = <ApiMethodInfo
 relative_path: 'v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}'
 method_id: 'dataflow.pro...ame: 'DataflowProjectsLocationsJobsGetRequest'
 response_type_name: 'Job'
 request_field: ''
 supports_download: False>
params = {'jobId': None, 'location': 'us-central1', 'projectId': 'apache-beam-testing'}
relative_path = '/v1b3/projects/{projectId}/locations/{location}/jobs/{jobId}'

    def ExpandRelativePath(method_config, params, relative_path=None):
        """Determine the relative path for request."""
        path = relative_path or method_config.relative_path or ''
    
        for param in method_config.path_params:
            param_template = '{%s}' % param
            # For more details about "reserved word expansion", see:
            #   http://tools.ietf.org/html/rfc6570#section-3.2.2
            reserved_chars = ''
            reserved_template = '{+%s}' % param
            if reserved_template in path:
                reserved_chars = _RESERVED_URI_CHARS
                path = path.replace(reserved_template, param_template)
            if param_template not in path:
                raise exceptions.InvalidUserInputError(
                    'Missing path parameter %s' % param)
            try:
                # TODO(craigcitro): Do we want to support some sophisticated
                # mapping here?
                value = params[param]
            except KeyError:
                raise exceptions.InvalidUserInputError(
                    'Request missing required parameter %s' % param)
            if value is None:
>               raise exceptions.InvalidUserInputError(
                    'Request missing required parameter %s' % param)
E               apitools.base.py.exceptions.InvalidUserInputError: Request missing required parameter jobId

../../build/gradleenv/-1734967050/lib/python3.9/site-packages/apitools/base/py/util.py:129: InvalidUserInputError

Check notice on line 0 in .github

See this annotation in the file changed.

@github-actions github-actions / Test Results

1 test found

There is 1 test, see "Raw output" for the name of the test.
Raw output
apache_beam.examples.wordcount_it_test.WordCountIT ‑ test_wordcount_it