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 2019/02/06 12:44:19 UTC

Build failed in Jenkins: beam_PostCommit_Python_Verify #7313

See <https://builds.apache.org/job/beam_PostCommit_Python_Verify/7313/display/redirect>

------------------------------------------
[...truncated 315.45 KB...]
test_streaming_data_only (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ERROR
test_streaming_with_attributes (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest) ... ERROR
test_copy (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_copy_batch (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_copy_batch_kms (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_copy_batch_rewrite_token (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_copy_kms (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_copy_rewrite_token (apache_beam.io.gcp.gcsio_integration_test.GcsIOIntegrationTest) ... ok
test_bigquery_read_1M_python (apache_beam.io.gcp.bigquery_io_read_it_test.BigqueryIOReadIT) ... ok
test_parquetio_it (apache_beam.io.parquetio_it_test.TestParquetIT) ... ok
test_avro_it (apache_beam.examples.fastavro_it_test.FastavroIT) ... ok
test_user_score_it (apache_beam.examples.complete.game.user_score_it_test.UserScoreIT) ... ok
test_hourly_team_score_it (apache_beam.examples.complete.game.hourly_team_score_it_test.HourlyTeamScoreIT) ... ok
test_big_query_legacy_sql (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok
test_big_query_new_types (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok
test_big_query_standard_sql (apache_beam.io.gcp.big_query_query_to_table_it_test.BigQueryQueryToTableIT) ... ok
test_datastore_write_limit (apache_beam.io.gcp.datastore_write_it_test.DatastoreWriteIT) ... ok

======================================================================
ERROR: test_game_stats_it (apache_beam.examples.complete.game.game_stats_it_test.GameStatsIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/complete/game/game_stats_it_test.py",> line 77, in setUp
    self.pub_client.topic_path(self.project, self.INPUT_TOPIC + _unique_id))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/_gapic.py",> line 44, in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/gapic/publisher_client.py",> line 271, in create_topic
    request, retry=retry, timeout=timeout, metadata=metadata)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/gapic_v1/method.py",> line 143, in __call__
    return wrapped_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 270, in retry_wrapped_func
    on_error=on_error,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 179, in retry_target
    return target()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/timeout.py",> line 214, in func_with_timeout
    return func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/grpc_helpers.py",> line 59, in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/six.py",> line 737, in raise_from
    raise value
ResourceExhausted: 429 Your project has exceeded a limit: (type="topics-per-project", current=10000, maximum=10000).
-------------------- >> begin captured logging << --------------------
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_leader_board_it (apache_beam.examples.complete.game.leader_board_it_test.LeaderBoardIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/complete/game/leader_board_it_test.py",> line 79, in setUp
    self.pub_client.topic_path(self.project, self.INPUT_TOPIC + _unique_id))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/_gapic.py",> line 44, in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/gapic/publisher_client.py",> line 271, in create_topic
    request, retry=retry, timeout=timeout, metadata=metadata)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/gapic_v1/method.py",> line 143, in __call__
    return wrapped_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 270, in retry_wrapped_func
    on_error=on_error,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 179, in retry_target
    return target()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/timeout.py",> line 214, in func_with_timeout
    return func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/grpc_helpers.py",> line 59, in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/six.py",> line 737, in raise_from
    raise value
ResourceExhausted: 429 Your project has exceeded a limit: (type="topics-per-project", current=10000, maximum=10000).
-------------------- >> begin captured logging << --------------------
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_streaming_wordcount_it (apache_beam.examples.streaming_wordcount_it_test.StreamingWordCountIT)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/examples/streaming_wordcount_it_test.py",> line 57, in setUp
    self.pub_client.topic_path(self.project, INPUT_TOPIC + self.uuid))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/_gapic.py",> line 44, in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/gapic/publisher_client.py",> line 271, in create_topic
    request, retry=retry, timeout=timeout, metadata=metadata)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/gapic_v1/method.py",> line 143, in __call__
    return wrapped_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 270, in retry_wrapped_func
    on_error=on_error,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 179, in retry_target
    return target()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/timeout.py",> line 214, in func_with_timeout
    return func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/grpc_helpers.py",> line 59, in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/six.py",> line 737, in raise_from
    raise value
ResourceExhausted: 429 Your project has exceeded a limit: (type="topics-per-project", current=10000, maximum=10000).
-------------------- >> begin captured logging << --------------------
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_streaming_data_only (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/pubsub_integration_test.py",> line 108, in setUp
    self.pub_client.topic_path(self.project, INPUT_TOPIC + self.uuid))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/_gapic.py",> line 44, in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/gapic/publisher_client.py",> line 271, in create_topic
    request, retry=retry, timeout=timeout, metadata=metadata)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/gapic_v1/method.py",> line 143, in __call__
    return wrapped_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 270, in retry_wrapped_func
    on_error=on_error,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 179, in retry_target
    return target()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/timeout.py",> line 214, in func_with_timeout
    return func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/grpc_helpers.py",> line 59, in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/six.py",> line 737, in raise_from
    raise value
ResourceExhausted: 429 Your project has exceeded a limit: (type="topics-per-project", current=10000, maximum=10000).
-------------------- >> begin captured logging << --------------------
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
--------------------- >> end captured logging << ---------------------

======================================================================
ERROR: test_streaming_with_attributes (apache_beam.io.gcp.pubsub_integration_test.PubSubIntegrationTest)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/apache_beam/io/gcp/pubsub_integration_test.py",> line 108, in setUp
    self.pub_client.topic_path(self.project, INPUT_TOPIC + self.uuid))
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/_gapic.py",> line 44, in <lambda>
    fx = lambda self, *a, **kw: wrapped_fx(self.api, *a, **kw)  # noqa
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/cloud/pubsub_v1/gapic/publisher_client.py",> line 271, in create_topic
    request, retry=retry, timeout=timeout, metadata=metadata)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/gapic_v1/method.py",> line 143, in __call__
    return wrapped_func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 270, in retry_wrapped_func
    on_error=on_error,
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/retry.py",> line 179, in retry_target
    return target()
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/timeout.py",> line 214, in func_with_timeout
    return func(*args, **kwargs)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/google/api_core/grpc_helpers.py",> line 59, in error_remapped_callable
    six.raise_from(exceptions.from_grpc_error(exc), exc)
  File "<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/build/gradleenv/1327086738/local/lib/python2.7/site-packages/six.py",> line 737, in raise_from
    raise value
ResourceExhausted: 429 Your project has exceeded a limit: (type="topics-per-project", current=10000, maximum=10000).
-------------------- >> begin captured logging << --------------------
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 25 tests in 2374.636s

FAILED (errors=5)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-8191660303927587988?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_12_10-14824537859265426163?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_17_39-10165603404300648702?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_25_02-11187685020615674558?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_31_06-1873405582070152977?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_37_25-4994028822805581203?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-9830277827739666929?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_12_25-14260503805980196259?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_53-11729642912411963096?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-9042510108788747118?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_11_54-6753164062238337080?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-10709825337830114967?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-2867811290225777563?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_53-4276727814264171923?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_11_54-7563579489214314623?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_18_24-10792747092429154790?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_24_53-10218716156123243350?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_04_54-4762403230559682466?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_04_13_03-13491541831469033714?project=apache-beam-testing.

> Task :beam-sdks-python:postCommitIT FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 147

* What went wrong:
Execution failed for task ':beam-sdks-python:directRunnerIT'.
> 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.
-----------
* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 266

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitIT'.
> 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

BUILD FAILED in 43m 56s
6 actionable tasks: 6 executed

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

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

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


Build failed in Jenkins: beam_PostCommit_Python_Verify #7315

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

Changes:

[aaltay] [BEAM-6540] Windmill quota piping (#7664)

------------------------------------------
[...truncated 363.07 KB...]
    {
      "kind": "ParallelDo", 
      "name": "s8", 
      "properties": {
        "display_data": [
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "format_result"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                  "component_encodings": [
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": [], 
                      "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                    }, 
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": [], 
                      "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                    }
                  ], 
                  "is_pair_like": true, 
                  "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                }, 
                {
                  "@type": "kind:interval_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "format.out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "step_name": "s7"
        }, 
        "serialized_fn": "ref_AppliedPTransform_format_10", 
        "user_name": "format"
      }
    }, 
    {
      "kind": "ParallelDo", 
      "name": "s9", 
      "properties": {
        "display_data": [
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "<lambda>"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "kind:bytes"
                }, 
                {
                  "@type": "kind:interval_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "encode.out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "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": "out", 
          "step_name": "s9"
        }, 
        "pubsub_topic": "projects/apache-beam-testing/topics/wc_topic_outputde91396e-a0b3-42ab-b6b3-2dd575fe771d", 
        "user_name": "WriteToPubSub/Write/NativeWrite"
      }
    }
  ], 
  "type": "JOB_TYPE_STREAMING"
}
root: INFO: Create job: <Job
 createTime: u'2019-02-06T18:17:23.437879Z'
 currentStateTime: u'1970-01-01T00:00:00Z'
 id: u'2019-02-06_10_17_22-2089222134636801829'
 location: u'us-central1'
 name: u'beamapp-jenkins-0206181715-923579'
 projectId: u'apache-beam-testing'
 stageStates: []
 startTime: u'2019-02-06T18:17:23.437879Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_STREAMING, 2)>
root: INFO: Created job with id: [2019-02-06_10_17_22-2089222134636801829]
root: INFO: To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_17_22-2089222134636801829?project=apache-beam-testing
root: INFO: Job 2019-02-06_10_17_22-2089222134636801829 is in state JOB_STATE_RUNNING
root: INFO: 2019-02-06T18:17:28.877Z: JOB_MESSAGE_DETAILED: Checking permissions granted to controller Service Account.
root: INFO: 2019-02-06T18:17:29.971Z: JOB_MESSAGE_BASIC: Worker configuration: n1-standard-4 in us-central1-b.
root: INFO: 2019-02-06T18:17:30.369Z: JOB_MESSAGE_DETAILED: Expanding CollectionToSingleton operations into optimizable parts.
root: INFO: 2019-02-06T18:17:30.391Z: JOB_MESSAGE_DETAILED: Expanding CoGroupByKey operations into optimizable parts.
root: INFO: 2019-02-06T18:17:30.411Z: JOB_MESSAGE_DETAILED: Expanding SplittableProcessKeyed operations into optimizable parts.
root: INFO: 2019-02-06T18:17:30.416Z: JOB_MESSAGE_DETAILED: Expanding GroupByKey operations into streaming Read/Write steps
root: INFO: 2019-02-06T18:17:30.428Z: JOB_MESSAGE_DEBUG: Annotating graph with Autotuner information.
root: INFO: 2019-02-06T18:17:30.452Z: JOB_MESSAGE_DETAILED: Fusing adjacent ParDo, Read, Write, and Flatten operations
root: INFO: 2019-02-06T18:17:30.458Z: JOB_MESSAGE_DETAILED: Fusing consumer decode into ReadFromPubSub/Read
root: INFO: 2019-02-06T18:17:30.463Z: JOB_MESSAGE_DETAILED: Fusing consumer pair_with_one into split
root: INFO: 2019-02-06T18:17:30.476Z: JOB_MESSAGE_DETAILED: Fusing consumer count into group/MergeBuckets
root: INFO: 2019-02-06T18:17:30.482Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteToPubSub/Write/NativeWrite into encode
root: INFO: 2019-02-06T18:17:30.486Z: JOB_MESSAGE_DETAILED: Fusing consumer encode into format
root: INFO: 2019-02-06T18:17:30.496Z: JOB_MESSAGE_DETAILED: Fusing consumer group/MergeBuckets into group/ReadStream
root: INFO: 2019-02-06T18:17:30.499Z: JOB_MESSAGE_DETAILED: Fusing consumer format into count
root: INFO: 2019-02-06T18:17:30.502Z: JOB_MESSAGE_DETAILED: Fusing consumer group/WriteStream into WindowInto(WindowIntoFn)
root: INFO: 2019-02-06T18:17:30.505Z: JOB_MESSAGE_DETAILED: Fusing consumer split into decode
root: INFO: 2019-02-06T18:17:30.509Z: JOB_MESSAGE_DETAILED: Fusing consumer WindowInto(WindowIntoFn) into pair_with_one
root: INFO: 2019-02-06T18:17:30.527Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
root: INFO: 2019-02-06T18:17:30.590Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
root: INFO: 2019-02-06T18:17:30.604Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
root: INFO: 2019-02-06T18:17:30.769Z: JOB_MESSAGE_DEBUG: Executing wait step start2
root: INFO: 2019-02-06T18:17:30.788Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
root: INFO: 2019-02-06T18:17:30.794Z: JOB_MESSAGE_BASIC: Starting 1 workers...
root: INFO: 2019-02-06T18:17:33.198Z: JOB_MESSAGE_BASIC: Executing operation ReadFromPubSub/Read+decode+split+pair_with_one+WindowInto(WindowIntoFn)+group/WriteStream
root: INFO: 2019-02-06T18:17:33.208Z: JOB_MESSAGE_BASIC: Executing operation group/ReadStream+group/MergeBuckets+count+format+encode+WriteToPubSub/Write/NativeWrite
root: WARNING: Timing out on waiting for job 2019-02-06_10_17_22-2089222134636801829 after 180 seconds
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
root: ERROR: Timeout after 400 sec. Received 0 messages from projects/apache-beam-testing/subscriptions/wc_subscription_outputde91396e-a0b3-42ab-b6b3-2dd575fe771d.
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 25 tests in 3185.333s

FAILED (failures=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-7408196767654221110?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_29_32-3710539958795637618?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_35_42-5974834937212088893?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_42_16-1122751843961743379?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_50_30-6422122949292985231?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_56_40-1866206469100794380?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_02-17191598429183831214?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_24_37-10133114240754024565?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-10253655462843804645?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_02-16811901235092207889?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_22_59-1829751266837937834?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_30_34-11339721619759303066?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_36_54-15326215911360931619?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-17750409714395272694?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_17_22-2089222134636801829?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-17099747402735013983?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_17_46-12991707805800445191?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_30_03-1576548303045336324?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_36_55-12438186470449820770?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-17759529680564865651?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_17_42-17535912021655684350?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_30_28-7464516196148444221?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_10_01-6684683704406225588?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_10_21_21-5254444083813356616?project=apache-beam-testing.

> Task :beam-sdks-python:postCommitIT FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 266

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitIT'.
> 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

BUILD FAILED in 58m 13s
6 actionable tasks: 6 executed

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

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

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


Build failed in Jenkins: beam_PostCommit_Python_Verify #7314

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

Changes:

[robert] Use the same noescape that the Go standard library in ioutilx

[robert] Remove noisy logging.

------------------------------------------
[...truncated 472.01 KB...]
            "namespace": "apache_beam.transforms.core.CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "<lambda>"
          }, 
          {
            "key": "fn", 
            "label": "Transform Function", 
            "namespace": "apache_beam.transforms.core.ParDo", 
            "shortValue": "CallableWrapperDoFn", 
            "type": "STRING", 
            "value": "apache_beam.transforms.core.CallableWrapperDoFn"
          }
        ], 
        "non_parallel_inputs": {}, 
        "output_info": [
          {
            "encoding": {
              "@type": "kind:windowed_value", 
              "component_encodings": [
                {
                  "@type": "kind:pair", 
                  "component_encodings": [
                    {
                      "@type": "kind:bytes"
                    }, 
                    {
                      "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                      "component_encodings": [
                        {
                          "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                          "component_encodings": [], 
                          "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                        }, 
                        {
                          "@type": "FastPrimitivesCoder$eNprYEpOLEhMzkiNT0pNzNVLzk9JLSqGUlxuicUlAUWZuZklmWWpxc4gQa5CBs3GQsbaQqZQ/vi0xJycpMTk7Hiw+kJmPEYFZCZn56RCjWABGsFaW8iWVJykBwDlGS3/", 
                          "component_encodings": [], 
                          "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                        }
                      ], 
                      "is_pair_like": true, 
                      "pipeline_proto_coder_id": "ref_Coder_FastPrimitivesCoder_3"
                    }
                  ], 
                  "is_pair_like": true
                }, 
                {
                  "@type": "kind:interval_window"
                }
              ], 
              "is_wrapper": true
            }, 
            "output_name": "out", 
            "user_name": "FilterOutSpammers/MapToVoidKey0.out"
          }
        ], 
        "parallel_input": {
          "@type": "OutputReference", 
          "output_name": "out", 
          "step_name": "s20"
        }, 
        "serialized_fn": "ref_AppliedPTransform_FilterOutSpammers/MapToVoidKey0_56", 
        "user_name": "FilterOutSpammers/MapToVoidKey0"
      }
    }
  ], 
  "type": "JOB_TYPE_STREAMING"
}
root: INFO: Create job: <Job
 createTime: u'2019-02-06T17:12:33.612048Z'
 currentStateTime: u'1970-01-01T00:00:00Z'
 id: u'2019-02-06_09_12_32-2845473242443885725'
 location: u'us-central1'
 name: u'beamapp-jenkins-0206171224-412787'
 projectId: u'apache-beam-testing'
 stageStates: []
 startTime: u'2019-02-06T17:12:33.612048Z'
 steps: []
 tempFiles: []
 type: TypeValueValuesEnum(JOB_TYPE_STREAMING, 2)>
root: INFO: Created job with id: [2019-02-06_09_12_32-2845473242443885725]
root: INFO: To access the Dataflow monitoring console, please navigate to https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_32-2845473242443885725?project=apache-beam-testing
root: INFO: Job 2019-02-06_09_12_32-2845473242443885725 is in state JOB_STATE_RUNNING
root: INFO: 2019-02-06T17:12:38.455Z: JOB_MESSAGE_DETAILED: Checking permissions granted to controller Service Account.
root: INFO: 2019-02-06T17:12:39.423Z: JOB_MESSAGE_BASIC: Worker configuration: n1-standard-4 in us-central1-b.
root: INFO: 2019-02-06T17:12:39.910Z: JOB_MESSAGE_DETAILED: Expanding CollectionToSingleton operations into optimizable parts.
root: INFO: 2019-02-06T17:12:39.930Z: JOB_MESSAGE_DETAILED: Expanding CoGroupByKey operations into optimizable parts.
root: INFO: 2019-02-06T17:12:39.957Z: JOB_MESSAGE_DEBUG: Combiner lifting skipped for step FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey: GroupByKey not followed by a combiner.
root: INFO: 2019-02-06T17:12:39.970Z: JOB_MESSAGE_DEBUG: Combiner lifting skipped for step CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey: GroupByKey not followed by a combiner.
root: INFO: 2019-02-06T17:12:39.985Z: JOB_MESSAGE_DETAILED: Expanding SplittableProcessKeyed operations into optimizable parts.
root: INFO: 2019-02-06T17:12:39.990Z: JOB_MESSAGE_DETAILED: Expanding GroupByKey operations into streaming Read/Write steps
root: INFO: 2019-02-06T17:12:40.043Z: JOB_MESSAGE_DEBUG: Annotating graph with Autotuner information.
root: INFO: 2019-02-06T17:12:40.078Z: JOB_MESSAGE_DETAILED: Fusing adjacent ParDo, Read, Write, and Flatten operations
root: INFO: 2019-02-06T17:12:40.082Z: JOB_MESSAGE_DETAILED: Fusing consumer WindowIntoFixedWindows into AddEventTimestamps
root: INFO: 2019-02-06T17:12:40.085Z: JOB_MESSAGE_DETAILED: Fusing consumer ExtractUserScores into AddEventTimestamps
root: INFO: 2019-02-06T17:12:40.089Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/MapToVoidKey0 into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/UnKey
root: INFO: 2019-02-06T17:12:40.093Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/MapToVoidKey0 into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/UnKey
root: INFO: 2019-02-06T17:12:40.096Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/MapToVoidKey0 into CreateSpammersView/UnKey
root: INFO: 2019-02-06T17:12:40.100Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/MapToVoidKey0 into CreateSpammersView/UnKey
root: INFO: 2019-02-06T17:12:40.105Z: JOB_MESSAGE_DETAILED: Fusing consumer WindowIntoSessions into ExtractUserScores
root: INFO: 2019-02-06T17:12:40.110Z: JOB_MESSAGE_DETAILED: Fusing consumer UserFixedWindows into ExtractUserScores
root: INFO: 2019-02-06T17:12:40.114Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/Values into CalculateSpammyUsers/SumUsersScores/Combine
root: INFO: 2019-02-06T17:12:40.119Z: JOB_MESSAGE_DETAILED: Fusing consumer ParseGameEventFn into ReadPubSub/Read
root: INFO: 2019-02-06T17:12:40.123Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey into CalculateSpammyUsers/ProcessAndFilter/MapToVoidKey0
root: INFO: 2019-02-06T17:12:40.127Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter into FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values
root: INFO: 2019-02-06T17:12:40.131Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values into FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.133Z: JOB_MESSAGE_DETAILED: Fusing consumer FormatAvgSessionLength into CombineGlobally(MeanCombineFn)/UnKey
root: INFO: 2019-02-06T17:12:40.135Z: JOB_MESSAGE_DETAILED: Fusing consumer CombineGlobally(MeanCombineFn)/UnKey into CombineGlobally(MeanCombineFn)/CombinePerKey/Combine
root: INFO: 2019-02-06T17:12:40.137Z: JOB_MESSAGE_DETAILED: Fusing consumer CombineGlobally(MeanCombineFn)/CombinePerKey/Combine into CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.139Z: JOB_MESSAGE_DETAILED: Fusing consumer CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets into CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.143Z: JOB_MESSAGE_DETAILED: Fusing consumer CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/WriteStream into CombineGlobally(MeanCombineFn)/KeyWithVoid
root: INFO: 2019-02-06T17:12:40.145Z: JOB_MESSAGE_DETAILED: Fusing consumer CombineGlobally(MeanCombineFn)/KeyWithVoid into WindowToExtractSessionMean
root: INFO: 2019-02-06T17:12:40.148Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteAvgSessionLength/ConvertToRow into FormatAvgSessionLength
root: INFO: 2019-02-06T17:12:40.152Z: JOB_MESSAGE_DETAILED: Fusing consumer UserSessionActivity into CombinePerKey(<lambda at game_stats.py:373>)/Combine
root: INFO: 2019-02-06T17:12:40.157Z: JOB_MESSAGE_DETAILED: Fusing consumer CombinePerKey(<lambda at game_stats.py:373>)/Combine into CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.160Z: JOB_MESSAGE_DETAILED: Fusing consumer CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/MergeBuckets into CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.165Z: JOB_MESSAGE_DETAILED: Fusing consumer CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/WriteStream into WindowIntoSessions
root: INFO: 2019-02-06T17:12:40.169Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteTeamScoreSums/WriteToBigQuery/WriteToBigQuery into WriteTeamScoreSums/ConvertToRow
root: INFO: 2019-02-06T17:12:40.172Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteTeamScoreSums/ConvertToRow into TeamScoresDict
root: INFO: 2019-02-06T17:12:40.176Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/SumUsersScores/Combine into CalculateSpammyUsers/SumUsersScores/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.179Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets into FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.182Z: JOB_MESSAGE_DETAILED: Fusing consumer ExtractAndSumScore/CombinePerKey(sum)/Combine into ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.186Z: JOB_MESSAGE_DETAILED: Fusing consumer ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/MergeBuckets into ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.192Z: JOB_MESSAGE_DETAILED: Fusing consumer ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/WriteStream into ExtractAndSumScore/Map(<lambda at game_stats.py:138>)
root: INFO: 2019-02-06T17:12:40.196Z: JOB_MESSAGE_DETAILED: Fusing consumer ExtractAndSumScore/Map(<lambda at game_stats.py:138>) into FilterOutSpammers/FilterOutSpammers
root: INFO: 2019-02-06T17:12:40.199Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream into FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey
root: INFO: 2019-02-06T17:12:40.204Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/SumUsersScores/GroupByKey/MergeBuckets into CalculateSpammyUsers/SumUsersScores/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.210Z: JOB_MESSAGE_DETAILED: Fusing consumer FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey into FilterOutSpammers/MapToVoidKey0
root: INFO: 2019-02-06T17:12:40.213Z: JOB_MESSAGE_DETAILED: Fusing consumer WriteAvgSessionLength/WriteToBigQuery/WriteToBigQuery into WriteAvgSessionLength/ConvertToRow
root: INFO: 2019-02-06T17:12:40.215Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/UnKey into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/Combine
root: INFO: 2019-02-06T17:12:40.219Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/Combine into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.222Z: JOB_MESSAGE_DETAILED: Fusing consumer CreateSpammersView/CombinePerKey/Combine into CreateSpammersView/CombinePerKey/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.226Z: JOB_MESSAGE_DETAILED: Fusing consumer CreateSpammersView/UnKey into CreateSpammersView/CombinePerKey/Combine
root: INFO: 2019-02-06T17:12:40.229Z: JOB_MESSAGE_DETAILED: Fusing consumer WindowToExtractSessionMean into UserSessionActivity
root: INFO: 2019-02-06T17:12:40.231Z: JOB_MESSAGE_DETAILED: Fusing consumer CreateSpammersView/CombinePerKey/GroupByKey/WriteStream into CreateSpammersView/KeyWithVoid
root: INFO: 2019-02-06T17:12:40.238Z: JOB_MESSAGE_DETAILED: Fusing consumer CreateSpammersView/KeyWithVoid into CalculateSpammyUsers/ProcessAndFilter/ProcessAndFilter
root: INFO: 2019-02-06T17:12:40.242Z: JOB_MESSAGE_DETAILED: Fusing consumer TeamScoresDict into ExtractAndSumScore/CombinePerKey(sum)/Combine
root: INFO: 2019-02-06T17:12:40.247Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values into CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets
root: INFO: 2019-02-06T17:12:40.253Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets into CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.259Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream into CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey
root: INFO: 2019-02-06T17:12:40.264Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/SumUsersScores/GroupByKey/WriteStream into UserFixedWindows
root: INFO: 2019-02-06T17:12:40.268Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.279Z: JOB_MESSAGE_DETAILED: Fusing consumer CreateSpammersView/CombinePerKey/GroupByKey/MergeBuckets into CreateSpammersView/CombinePerKey/GroupByKey/ReadStream
root: INFO: 2019-02-06T17:12:40.288Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/WriteStream into CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/KeyWithVoid
root: INFO: 2019-02-06T17:12:40.294Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/KeyWithVoid into CalculateSpammyUsers/Values
root: INFO: 2019-02-06T17:12:40.301Z: JOB_MESSAGE_DETAILED: Fusing consumer AddEventTimestamps into ParseGameEventFn
root: INFO: 2019-02-06T17:12:40.307Z: JOB_MESSAGE_DETAILED: Fusing consumer CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter into CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values
root: INFO: 2019-02-06T17:12:40.363Z: JOB_MESSAGE_DEBUG: Adding StepResource setup and teardown to workflow graph.
root: INFO: 2019-02-06T17:12:40.413Z: JOB_MESSAGE_DEBUG: Adding workflow start and stop steps.
root: INFO: 2019-02-06T17:12:40.463Z: JOB_MESSAGE_DEBUG: Assigning stage ids.
root: INFO: 2019-02-06T17:12:40.608Z: JOB_MESSAGE_DEBUG: Executing wait step start2
root: INFO: 2019-02-06T17:12:40.626Z: JOB_MESSAGE_DEBUG: Starting worker pool setup.
root: INFO: 2019-02-06T17:12:40.640Z: JOB_MESSAGE_BASIC: Starting 1 workers...
root: INFO: 2019-02-06T17:12:43.197Z: JOB_MESSAGE_BASIC: Executing operation CalculateSpammyUsers/SumUsersScores/Combine.out/FromValue/ReadStream+CalculateSpammyUsers/ProcessAndFilter/ProcessAndFilter+CreateSpammersView/KeyWithVoid+CreateSpammersView/CombinePerKey/GroupByKey/WriteStream
root: INFO: 2019-02-06T17:12:43.206Z: JOB_MESSAGE_BASIC: Executing operation WindowIntoFixedWindows.out/FromValue/ReadStream+FilterOutSpammers/FilterOutSpammers+ExtractAndSumScore/Map(<lambda at game_stats.py:138>)+ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/WriteStream
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/ReadStream+CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/MergeBuckets+CombinePerKey(<lambda at game_stats.py:373>)/Combine+UserSessionActivity+WindowToExtractSessionMean+CombineGlobally(MeanCombineFn)/KeyWithVoid+CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/WriteStream
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CalculateSpammyUsers/SumUsersScores/GroupByKey/ReadStream+CalculateSpammyUsers/SumUsersScores/GroupByKey/MergeBuckets+CalculateSpammyUsers/SumUsersScores/Combine+CalculateSpammyUsers/Values+CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/KeyWithVoid+CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/WriteStream+CalculateSpammyUsers/SumUsersScores/Combine.out/FromValue/WriteStream
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/ReadStream+CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+CombineGlobally(MeanCombineFn)/CombinePerKey/Combine+CombineGlobally(MeanCombineFn)/UnKey+FormatAvgSessionLength+WriteAvgSessionLength/ConvertToRow+WriteAvgSessionLength/WriteToBigQuery/WriteToBigQuery
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/ReadStream+CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/GroupByKey/MergeBuckets+CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/CombinePerKey/Combine+CalculateSpammyUsers/CombineGlobally(MeanCombineFn)/UnKey+CalculateSpammyUsers/ProcessAndFilter/MapToVoidKey0+CalculateSpammyUsers/ProcessAndFilter/MapToVoidKey0+CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values+CalculateSpammyUsers/ProcessAndFilter/_DataflowIterableSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
root: INFO: 2019-02-06T17:12:43.208Z: JOB_MESSAGE_BASIC: Executing operation CreateSpammersView/CombinePerKey/GroupByKey/ReadStream+CreateSpammersView/CombinePerKey/GroupByKey/MergeBuckets+CreateSpammersView/CombinePerKey/Combine+CreateSpammersView/UnKey+FilterOutSpammers/MapToVoidKey0+FilterOutSpammers/MapToVoidKey0+FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/PairWithVoidKey+FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/WriteStream
root: INFO: 2019-02-06T17:12:43.216Z: JOB_MESSAGE_BASIC: Executing operation ReadPubSub/Read+ParseGameEventFn+AddEventTimestamps+WindowIntoFixedWindows+ExtractUserScores+WindowIntoSessions+UserFixedWindows+CombinePerKey(<lambda at game_stats.py:373>)/GroupByKey/WriteStream+CalculateSpammyUsers/SumUsersScores/GroupByKey/WriteStream+WindowIntoFixedWindows.out/FromValue/WriteStream
root: INFO: 2019-02-06T17:12:43.216Z: JOB_MESSAGE_BASIC: Executing operation FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/ReadStream+FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/GroupByKey/MergeBuckets+FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/Values+FilterOutSpammers/_DataflowIterableSideInput(MapToVoidKey0.out.0)/StreamingPCollectionViewWriter
root: INFO: 2019-02-06T17:12:43.219Z: JOB_MESSAGE_BASIC: Executing operation ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/ReadStream+ExtractAndSumScore/CombinePerKey(sum)/GroupByKey/MergeBuckets+ExtractAndSumScore/CombinePerKey(sum)/Combine+TeamScoresDict+WriteTeamScoreSums/ConvertToRow+WriteTeamScoreSums/WriteToBigQuery/WriteToBigQuery
root: INFO: 2019-02-06T17:14:04.136Z: JOB_MESSAGE_DEBUG: Executing input step topology_init_attach_disk_input_step
root: INFO: 2019-02-06T17:14:07.086Z: JOB_MESSAGE_DETAILED: Workers have started successfully.
root: WARNING: Timing out on waiting for job 2019-02-06_09_12_32-2845473242443885725 after 723 seconds
root: INFO: Start verify Bigquery data.
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
urllib3.util.retry: DEBUG: Converted retries value: 3 -> Retry(total=3, connect=None, read=None, redirect=None, status=None)
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
urllib3.connectionpool: DEBUG: Starting new HTTPS connection (1): www.googleapis.com:443
urllib3.connectionpool: DEBUG: https://www.googleapis.com:443 "POST /bigquery/v2/projects/apache-beam-testing/jobs HTTP/1.1" 200 None
urllib3.connectionpool: DEBUG: https://www.googleapis.com:443 "GET /bigquery/v2/projects/apache-beam-testing/queries/51035f03-a71e-4e20-a3ff-983784f5e4a4?location=US&maxResults=0 HTTP/1.1" 200 None
urllib3.connectionpool: DEBUG: https://www.googleapis.com:443 "GET /bigquery/v2/projects/apache-beam-testing/jobs/51035f03-a71e-4e20-a3ff-983784f5e4a4?location=US HTTP/1.1" 200 None
urllib3.connectionpool: DEBUG: https://www.googleapis.com:443 "GET /bigquery/v2/projects/apache-beam-testing/datasets/_7357fab0f784d2a7327ddbe81cdd1f4ca7e429cd/tables/anon106b3b91_5560_4467_81c9_256f6fdf45ef/data HTTP/1.1" 200 None
root: INFO: Read from given query (SELECT mean_duration FROM `apache-beam-testing.game_stats_it_dataset1549473143.game_stats_sessions` WHERE mean_duration=300 LIMIT 1), total rows 1
root: INFO: Generate checksum: 5288ccaab77d347c8460d77c15a0db234ef5eb4f
google.auth.transport._http_client: DEBUG: Making request: GET http://169.254.169.254
google.auth.transport._http_client: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/project/project-id
urllib3.util.retry: DEBUG: Converted retries value: 3 -> Retry(total=3, connect=None, read=None, redirect=None, status=None)
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/default/?recursive=true
urllib3.connectionpool: DEBUG: Starting new HTTP connection (1): metadata.google.internal:80
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/default/?recursive=true HTTP/1.1" 200 144
google.auth.transport.requests: DEBUG: Making request: GET http://metadata.google.internal/computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token
urllib3.connectionpool: DEBUG: http://metadata.google.internal:80 "GET /computeMetadata/v1/instance/service-accounts/844138762903-compute@developer.gserviceaccount.com/token HTTP/1.1" 200 176
urllib3.connectionpool: DEBUG: Starting new HTTPS connection (1): www.googleapis.com:443
urllib3.connectionpool: DEBUG: https://www.googleapis.com:443 "DELETE /bigquery/v2/projects/apache-beam-testing/datasets/game_stats_it_dataset1549473143?deleteContents=true HTTP/1.1" 204 0
--------------------- >> end captured logging << ---------------------

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 25 tests in 2948.896s

FAILED (errors=1)
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_32-2845473242443885725?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_27_07-12851060096836981385?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_31-9675823837025311920?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_33-7340784901270806747?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_25_40-14936961845522493184?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_31_23-15579687606274722046?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_37_45-9298900482137899382?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_32-7853866195671946391?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_30-6883515119633272404?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_19_54-16742224437251433872?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_29_52-16582340545051389180?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_31-4420673693758501832?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_20_02-7196389517302364336?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_27_42-12813635923132398790?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_34_27-13745152244075525641?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_41_22-7479649893259066396?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_48_02-5815869096917169098?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_54_52-16998643812921499769?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_31-15014309800255449403?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_20_47-6953583813958772140?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_28_04-8733753414539318349?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_34_35-2973876068008680278?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_12_31-18198118587041956103?project=apache-beam-testing.
Found: https://console.cloud.google.com/dataflow/jobsDetail/locations/us-central1/jobs/2019-02-06_09_21_41-11301859997289213392?project=apache-beam-testing.

> Task :beam-sdks-python:postCommitIT FAILED

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_PostCommit_Python_Verify/ws/src/sdks/python/build.gradle'> line: 266

* What went wrong:
Execution failed for task ':beam-sdks-python:postCommitIT'.
> 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

BUILD FAILED in 54m 6s
6 actionable tasks: 6 executed

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

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

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