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/05/23 14:25:10 UTC

Build failed in Jenkins: beam_LoadTests_Python_GBK_Dataflow_Batch #5

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

Changes:

[jkp] Loosen up dependency specifications

[samuelw] GrpcWindmillWorker improvements: - Log error statuses returned from

[github] Add upper bounds.

[ttanay100] withNumFileShards must be used when using withTriggeringFrequency

[ehudm] [BEAM-6669] Set Dataflow KMS key name (Python)

[juta.staes] [BEAM-6769] write bytes to bigquery in python 2

[robinyqiu] Use a singleton PIPELINE_OPTION_PARAMETER in DoFnSignature.Parameter

[roman] fix splitting into filters and buckets

[roman] tidy up println

[kcweaver] [BEAM-7110] Add Spark master option to SparkJobServerDriver

[ehudm] [BEAM-7062] Fix pydoc for @retry.with_exponential_backoff

[ehudm] Make utility functions private ...

[kcweaver] [BEAM-7133] make Spark job server Gradle task pass along system

[heejong] [BEAM-7143] adding withConsumerConfigUpdates

[robertwb] Allow inference of CombiningValueState coders.

[robert] Avoid depending on context formating in hooks_test

[michal.walenia] [BEAM-6627] Generify ByteMonitor to accept any type, not just KV<byte[],

[michal.walenia] [BEAM-6627] Add CountMonitor to IOIT metric utils

[robertwb] [BEAM-7157] Allow creation of BinaryCombineFn from lambdas.

[robertwb] [BEAM-2939] Support SDF expansion in the Flink runner.

[pabloem] Add some pydoc for runner classes in Python

[valentyn] Adds a possibility to pass a project that hosts Cloud Spanner instance

[iemejia] [BEAM-7162] Add ValueProvider to CassandraIO Write

[iemejia] [BEAM-6479] Deprecate AvroIO.RecordFormatter

[iemejia] [BEAM-5311] Delete docker build images

[ehudm] Python Datastore IO using google-cloud-datastore

[ajamato] Update dataflow container version to beam-master-20190426

[daniel.o.programmer] [BEAM-7087] Updating Go SDK errors in base beam directory

[daniel.o.programmer] [BEAM-7087] Moving "errors" package to its own subdirectory.

[github] Merge pull request #8311: Allow Schema field selections in DoFn using

[iemejia] [BEAM-7076] Update Spark runner to use spark version 2.4.2

[iemejia] [BEAM-6526] Add ReadFiles and ParseFiles transforms for AvroIO

[relax] Ensure that all nested schemas are given ids, and fix bug where nullable

[thw] [BEAM-7112] Timer race with state cleanup - take two

[robertwb] fixup

[mxm] [BEAM-7170] Fix exception when retrieving ExpansionServer port after

[aromanenko.dev] [BEAM-6850] Use HadoopFormatIOIT for perfomance/integration testing

[chamikara] Updates Dataflow runner to support external ParDos.

[kedin] [BEAM-7072][SQL][Nexmark] Disable Query5

[daniel.o.programmer] [BEAM-7087] Updating Go SDK errors (Part 1)

[daniel.o.programmer] [BEAM-7178] Adding simple package comment to Go "errors" package.

[jiangkai] upgrade avatica to 1.14.0

[juta.staes] [BEAM-6621][BEAM-6624] add direct runner and dataflow runner it test

[ajamato] [BEAM-4374] Emit SampledByteCount distribution tuple system metric from

[pabloem] Support the newest version of httplib2 (#8263)

[github] Add clarifying comment for MonitoringInfoLabel usage.

[lcwik] [BEAM-3344] Changes for serialize/deserialize PipelineOptions via

[amaliujia] [BEAM-7166] Add more checks on join condition.

[kcweaver] [BEAM-7176] don't reuse Spark context in tests (causes OOM)

[25622840+adude3141] [BEAM-6859] align teardown with setup calls also for empty streaming

[25622840+adude3141] [BEAM-7193] ParDoLifecycleTest: remove duplicated inner class

[github] Revert "[BEAM-5709] Changing sleeps to CountdownLatch in test"

[chamikara] Bumps down the httplib2 version since it conflicts with

[ehudm] Add pip check invocations to all tox environments.

[iemejia] [BEAM-6526] Remove unneeded methods in AvroIO ReadFiles and ParseFiles

[iemejia] [BEAM-6526] Refactor AvroIO Read/Parse to use FileIO +

[iemejia] [BEAM-6526] Add populateDisplayData on AvroIO.ReadFiles

[iemejia] [BEAM-7196] Add Display Data to FileIO Match/MatchAll

[lcwik] [BEAM-6669] Set Dataflow KMS key name (#8296)

[migryz] FnApiMonitoringInfoToCounterUpdateTranformer with User counters

[leo.unc] Use TFRecord to store intermediate cache results using PCollection's

[migryz] Downgrade logging level to avoid log spam

[kcweaver] [BEAM-7201] Go README: update task name

[lcwik] [BEAM-7179] Correct file extension (#8434)

[pabloem] Fixing fileio tests for windows

[iemejia] [BEAM-6605] Deprecate TextIO.readAll and TextIO.ReadAll transform

[iemejia] [BEAM-6605] Refactor TextIO.Read and its Tests to use FileIO + ReadFiles

[iemejia] [BEAM-6606] Deprecate AvroIO ReadAll and ParseAll transforms

[iemejia] [BEAM-7205] Remove MongoDb withKeepAlive configuration

[mxm] [BEAM-7171] Ensure bundle finalization during Flink checkpoint

[mxm] [website] Link design document on cross-language and legacy IO

[aromanenko.dev] [BEAM-6850] Add metrics collectioning to HadoopFormatIOIT

[iemejia] [BEAM-7211] Implement HasDefaultTracker interface in ByteKeyRange

[yoshiki.obata] [BEAM-7137] encode header to bytes when writing to file at

[ehudm] Update Dataflow BEAM_CONTAINER_VERSION

[yifanzou] [BEAM-7213] fix beam_PostRelease_NightlySnapshot

[relax] Fix non-determistic row access

[daniel.o.programmer] [BEAM-7154] Updating Go SDK errors (Part 2)

[bhulette] Move schema assignment onto Create builder

[yifanzou] [BEAM-7202] fix inventory jobs

[github] Adding documentation to DirectRunner functions. (#8464)

[angoenka] Update beam_fn_api.proto to specify allowed split points. (#8476)

[aromanenko.dev] [BEAM-6247] Remove deprecated module “hadoop-input-format”

[mxm] [BEAM-7192] Fix partitioning of buffered elements during checkpointing

[github] Update setup.py for pyarrow

[robert] fix format string errors with errors package.

[robert] Update Go protos.

[heejong] [BEAM-7008] adding UTF8 String coder to Java SDK ModelCoder

[heejong] [BEAM-7102] Adding `jar_packages` experiment option for Python SDK

[heejong] [BEAM-7220] add JavaReadViaImpulse substitution to Java expansion

[bhulette] Fix EXCEPT DISTINCT behavior

[iemejia] Refine Spark ValidatesRunner exclusions

[github] Add Bigtable to supported Beam connectors

[pabloem] [BEAM-2939] Initial SyntheticSDF as Source and add an Synthetic pipeline

[kcweaver] [BEAM-6966] Spark portable runner: translate READ

[amaliujia] [sql] reject aggreagtion distinct rather than executing distinct as all.

[juta.staes] [BEAM-7066] re-add python 3.6 and 3.7 precommit test suites

[iemejia] [BEAM-7227] Instantiate PipelineRunner from options to support other

[iemejia] Categorize missing unbounded NeedsRunner tests in sdks/java/core

[frederik.bode] Fix fastavro on Python 3

[frederik.bode] fixup: Fix fastavro on Python 3

[iemejia] Minor fixes related to NeedsRunner/ValidatesRunner tests

[mxm] [BEAM-5197] Guard access to test timer service by a lock

[25622840+adude3141] [BEAM-7229] ParDoLifecycleTest: remove duplicated test methods

[github] Adding PyDoc to CombiningValueStateSpec (#8477)

[iemejia] Add UsesSchema category to Schema transform tests

[iemejia] Categorize TestStreamsTest tests that use processing time

[pabloem] Skipping fileio tests on windows

[richard.moorhead] [BEAM-7216] reinstate checks for Kafka client methods

[markliu] Fix project path in beam_PerformanceTests_Python35

[relax] Merge pull request #8485: Fixed bug where fieldIdsAccessed order could

[ankurgoenka] Fix py3 "Map modified during iteration"

[echauchot] Add Structured streaming Spark Runner design document

[michal.walenia] [BEAM-7028] Add Combine Java load tests

[pabloem] Fixing fileio tests for windows

[boyuanz] Move test_sdf_synthetic_source to FnApiRunnerTest

[kcweaver] [BEAM-7214] Run Python validates runner tests on Spark

[leo.unc] Revert "Use TFRecord to store intermediate cache results using

[amaliujia] [BEAM-5644] make Planner configurable.

[pabloem] [BEAM-6986] TypeHints Py3 Error: Multiple tests fail with a generator

[25622840+adude3141] [BEAM-7197] ensure DoFn is torn down after exception thrown in lifecycle

[kedin] [SQL] Remove TYPE_ prefix from DataCatalogTableProvider

[kedin] [SQL] Refactor BeamSqlEnv

[kedin] [SQL][Fix] Fix DataCatalog MAP type

[github] [BEAM-7241] Bump the version of apitools.

[github] [BEAM-6892] Adding support for side inputs on table & schema. Also

[github] Adding Python samples to the Timely (and stateful) Processing post.

[kedin] [SQL] Upgrade DataCatalog client to 0.4.0-alpha

[iemejia] [BEAM-7239] Add withDataSourceProviderFn() to JdbcIO

[iemejia] [BEAM-7041] Refactor pool creation to be done via composition

[mxm] [BEAM-7012] Support TestStream in portable Flink Runner

[kcweaver] [BEAM-7134] Spark portable runner: executable stage sinks should have

[github] Update reviewer list for Py3 contributions.

[iemejia] [BEAM-7238] Make sfl4j-simple a runtime only dependency

[iemejia] [BEAM-7238] Make sfl4j-jdk14 a runtime only dependency

[github] [BEAM-7173] Avoiding schema autodetection by default in WriteToBigQuery

[ankurgoenka] Add and disable tests for optimized portable pipeline

[kcweaver] [BEAM-6959] Go SDK: support integration tests on Flink

[samuelw] Modify StreamingDataflowWorker commit loop to only create a commit

[github] Changes to SDF API to use DoFn Params (#8430)

[amaliujia] [sql] fix non return bug.

[altay] Downgrade missing coder error logs to info logs.

[rezarokni] Add Snippets for 3 new Beam Patterns 2 X FilePatterns 1 X SideInput

[ankurgoenka] Add Python optimized test for Flink

[michal.walenia] [BEAM-7228] Add a Jenkins job running ValidatesRunner tests for Direct

[michal.walenia] [BEAM-7005] Add streaming GBK load test

[ankurgoenka] Moving to 2.14.0-SNAPSHOT on master branch.

[heejong] [BEAM-7257] adding withProducerConfigUpdates

[heejong] [BEAM-7260] UTF8 coder is breaking dataflow tests

[iemejia] [BEAM-7263] Deprecate set/getClientConfiguration in JdbcIO

[iemejia] [BEAM-7265] Update Spark runner to use spark version 2.4.3

[michal.walenia] [BEAM-6627] Add byte and element counting to TextIOIT

[michal.walenia] [BEAM-6627] Add byte and element counting to AvroIOIT

[michal.walenia] [BEAM-6627] Add byte and element counting to ParquetIOIT

[michal.walenia] [BEAM-6627] Add byte and element count metric to XmlIOIT

[michal.walenia] [BEAM-6627] Add byte and element count metric in TFRecordIOIT

[michal.walenia] [BEAM-6627] Add byte and element counter metric to JdbcIOIT

[michal.walenia] [BEAM-6627] Add byte and item count metrics to MongoDBIOIT

[michal.walenia] [BEAM-6627] Add byte and item count metrics to JdbcIOIT

[mxm] [BEAM-7145] Make FlinkRunner compatible with Flink 1.8

[michal.walenia] [BEAM-7028] Change ParDo load test according to the proposal, add a

[juta.staes] [BEAM-7181][BEAM-7243] add streaming it tests python 3.6

[ankurgoenka] [BEAM-7267] Add python3*-dev to verify script

[ankurgoenka] Revert "Merge pull request #8228: [BEAM-7008] adding UTF8 String coder

[ankurgoenka] Revert "Merge pull request #8545 from ihji/BEAM-7260"

[je.ik] [BEAM-7269] remove StateSpec from hashCode of SimpleStateTag

[ankurgoenka] Updating python containers to beam-master-20190509

[charlesccychen] [BEAM-4858] Increase tolerance on linear regression tests (#8556)

[25622840+adude3141] [BEAM-4046] decouple gradle project names and maven artifact ids

[25622840+adude3141] [BEAM-4046] add project mappings and enable parsing of legacy commands

[daniel.o.programmer] [BEAM-7154] Updating Go SDK errors (Part 3)

[michal.walenia] [BEAM-6627] Add item and byte counters to HadoopFormatIOIT

[iemejia] [BEAM-7239] Do not close DataSource on Teardown on JdbcIO

[jkai] upgrade to avatica 1.15.0

[kedin] Small doc clean up

[kedin] [SQL] SpotlessApply for minor docs PR #8567

[melissapa] [BEAM-7281] Update Python deps page to current release

[heejong] [BEAM-7253] test_with_jar_packages_invalid_file_name test fails on

[kcweaver] [BEAM-7282] portable Spark: don't fuse already optimized graph

[lcwik] [BEAM-7283] Update aggregated javadoc versions during linking to point

[lcwik] [BEAM-7283] Build javadocs using online links for all dependencies

[altay] [BEAM-562] Add DoFn.setup and DoFn.teardown to Python SDK (#7994)

[tweise] Beam community update blogpost (#8559)

[iemejia] Fix trigger paths filters to execute precommit tests only if needed

[mxm] [BEAM-7126] Remove LengthPrefixCoder from Flink's key Coder

[mxm] [website] Update Flink Runner page for version 1.8

[mxm] Update references Dataflow to Beam in Flink Runner

[mxm] Add Coder components for BufferedElement Coder

[mxm] Remove UnboundedSocketSource from Flink Runner

[mxm] [BEAM-7271] adding UTF8 String coder to Java SDK ModelCoder

[ehudm] [BEAM-7251] Increase timeout for test BQ queries.

[kenn] Fix project dependencies in pom.xml outputs

[jozsi] Add first version of Hazelcast Jet based Java Runner

[ehudm] Add missing javadoc to BigqueryClient.java

[pabloem] [BEAM-6493] : Add cookbook and snippets examples in Kotlin (#8439)

[relax] Merge pull request #8358: Beam Kata for Java and Python SDKs

[ajamato] [BEAM-6138] Update java SDK to report user distribution tuple metrics

[25622840+adude3141] [BEAM-4046] revert test infra to be compatible with pending PRs

[25622840+adude3141] fix syntax errors in groovy files

[kcweaver] run job server on an unused port

[heejong] [BEAM-7103] Adding AvroCoderTranslator for cross-language data transfer

[github] Merge pull request #8425: [BEAM-7174] Add schema modification transforms

[jozo.vilcek] [BEAM-5865] Create optional auto-balancing sharding function for Flink

[jozo.vilcek] [BEAM-5865] Add unit tests and fix bug + changes from review

[jozo.vilcek] [BEAM-5865] Improve FlinkPipelineOptions javadoc

[robertwb] [BEAM-7121] Add deterministic proto coder (#8377)

[frederik.bode] Add Postcommit test suite for Python 3.7

[iemejia] Categorize tests from UsesTestStream to UsesTestStreamWithProcessingTime

[xinyuliu.us] [BEAM-7311] merge internal commits to beam open source trunk to prepare

[huangry] Create PAssert util function for late panes.

[robinyqiu] Simple fix: make use of Reify in Latest to replace duplicate code

[iemejia] [website] Add design doc on portable representation of schemas

[jozsi] Add various Jet Runner fixes & improvements

[jozsi] Add Jet-Runner to maven archetypes to facilitate easier running of

[athomas1] Modified KinesisIO to use WatermarkPolicyFactory for watermark

[25622840+adude3141] [BEAM-7302] ensure artifactId set on pom also with unconfigured project

[25622840+adude3141] [BEAM-7287] Change JAVA_HOME to match new Jenkins agents (#8584)

[iemejia] [BEAM-7230] Add javadoc on provided poolable data sources on JdbcIO

[boyuanz] Add retry strategy when TableRow or TableCell is null from BQ response.

[markliu] [BEAM-7339] Make input and checksum configurable for Python WordCountIT

[github] Remove unused attemptNum

[github] [BEAM-6908] Refactor Python performance test groovy file for easy

[aromanenko.dev] [BEAM-7349] Get back to "provided" scope for "kafka_clients"

[github] Fix a typo in setting.gradle

[markliu] [BEAM-7347] Pass dpb_service_zone flag to benchmarks to fix breakage

[kcweaver] [BEAM-7135] Spark: close job bundle factory

[markliu] [BEAM-7339] Enable 1Gb input for Python wordcount benchmark

[klk] Updates python SDK GCP client API in sync with the current Google

[markliu] Update README for beam_PerformanceTests_WordCountIT Jenkins job

[daniel.o.programmer] [BEAM-7154] Fixing small error bug.

[varundhussa] [BEAM-7286] RedisIO support for INCRBY/DECRBY operations

[github] [BEAM-7275] ParDoLifeCycleTest: collect lifecycle info for DoFn insta…

[hsuryawirawan] Fix the ContainsKv assertion which at times didn't work with some JDKs

[33895511+aromanenko-dev] [BEAM-7359] Fix static analysis issues for HadoopFormatIO (#8616)

[33895511+aromanenko-dev] [BEAM-7360] Fix static analysis issues for HCatalogIO (#8617)

[robertwb] [BEAM-7364] Avoid possible signed integer overflow in hash.

[mxm] [BEAM-7367] Add Kafka clients jar as a Docker dependency

[github] [BEAM-6988] Implement a Python 3 version of getcallargs_forhints (#8590)

[rtnguyen] Reorg Beam SQL docs and added Calcite section

[markliu] [BEAM-6908] Enable WordCountIT benchmark on Py36+37

[pabloem] [BEAM-6880] Remove deprecated Reference Runner code. (#8380)

[yifanzou] [BEAM-7371] fix dependency check

[migryz] Update stability critical jobs status

[valentyn] Add a passing test to postcommit suites.

[ehudm] [BEAM-7376] Update tox version used by gradle

[daniel.o.programmer] [BEAM-7373] Migrating vet runner

[mxm] [BEAM-7378] Fix Python PVR tests by adding a Kafka client dependency

[mxm] Change scope of runtime dependency to runtime

[mxm] [BEAM-7378] Add trigger to Python Flink PVR tests for Kafka module

[iemejia] [BEAM-7230] Make PoolableDataSourceProvider a static singleton And

[lcwik] [BEAM-6872] Add hook for user-defined JVM initialization in workers

[iemejia] Make sfl4j runtime only for Samza Job Server too

[markliu] Update .test-infra/jenkins/README

[altay] [BEAM-6695] Latest PTransform for Python SDK (#8206)

[altay] [BEAM-7354] Starcgen fix when no identifiers specified. (#8611)

[iemejia] [BEAM-6888] Enable SpotBugs in JdbcIO

[mxm] [BEAM-7366] Include the project's SourceSets in Spotless target

[mxm] Apply Spotless after fixing source directory detection

[mxm] Move StateContextsTest to let it execute as part of the tests

[kenn] [BEAM-5822] Vendor bytebuddy (#8357)

[valentyn] [BEAM-7365] Reduce the volume of test data in fastavro branch of

[valentyn] Support sync_interval in TestAvro._write_data() to simplify test

[daniel.o.programmer] [BEAM-6880] Removing python integration test for Java ULR.

[jozsi] Make Jet Runner usable and documented

------------------------------------------
[...truncated 123.37 KB...]
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/streaming_wordcount_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/wordcount_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/wordcount_xlang.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_side_input_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_side_input.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_tornadoes_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/multiple_output_pardo_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/filters_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/datastore_wordcount.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_tornadoes.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/custom_ptransform_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/group_with_coder_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_schema.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigquery_tornadoes_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/datastore_wordcount_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/mergecontacts.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/mergecontacts_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/bigtableio_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/group_with_coder.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/custom_ptransform.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/combiners_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/coders_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/coders.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/filters.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/cookbook/multiple_output_pardo.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/snippets/snippets_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/snippets/snippets.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/snippets/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/flink/flink_streaming_impulse.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/flink/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/distribopt_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/autocomplete_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/estimate_pi.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/tfidf.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/tfidf_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/autocomplete.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/top_wikipedia_sessions_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/distribopt.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/estimate_pi_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/top_wikipedia_sessions.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/game_stats_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/leader_board_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/user_score_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/hourly_team_score_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/leader_board_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/hourly_team_score.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/game_stats.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/leader_board.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/user_score_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/user_score.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/game_stats_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/game/hourly_team_score_it_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/setup.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/juliaset_main.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/juliaset/juliaset.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/juliaset/juliaset_test.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/examples/complete/juliaset/juliaset/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/python_urns.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/common_urns.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/metrics_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_fn_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/endpoints_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_artifact_api_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_expansion_api_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_expansion_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/metrics_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_provision_api_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_provision_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_job_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_runner_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/endpoints_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/external_transforms_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/standard_coders.yaml'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/standard_window_fns_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/__init__.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_fn_api_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/standard_window_fns_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_job_api_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/external_transforms_pb2.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_artifact_api_pb2_grpc.py'
adding 'apache-beam-2.14.0.dev0/apache_beam/portability/api/beam_runner_api_pb2.py'
Creating tar archive
removing 'apache-beam-2.14.0.dev0' (and everything under it)
sdist archive name: <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/sdks/python/apache_beam/testing/load_tests/build/apache-beam-2.14.0.dev0.tar.gz>

> Task :sdks:python:apache_beam:testing:load_tests:installGcpTest
DEPRECATION: Python 2.7 will reach the end of its life on January 1st, 2020. Please upgrade your Python as Python 2.7 won't be maintained after that date. A future version of pip will drop support for Python 2.7.
Obtaining file://<https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/sdks/python>
Collecting crcmod<2.0,>=1.7 (from apache-beam==2.14.0.dev0)
Collecting dill<0.2.10,>=0.2.9 (from apache-beam==2.14.0.dev0)
Collecting fastavro<0.22,>=0.21.4 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/15/8b/5d9736fec68e94ce4f98e98407b500c21d2faffcbdec52d09a96a0f68ddc/fastavro-0.21.23-cp27-cp27mu-manylinux1_x86_64.whl
Requirement already satisfied: future<1.0.0,>=0.16.0 in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from apache-beam==2.14.0.dev0) (0.16.0)
Requirement already satisfied: grpcio<2,>=1.8 in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from apache-beam==2.14.0.dev0) (1.20.1)
Collecting hdfs<3.0.0,>=2.1.0 (from apache-beam==2.14.0.dev0)
Collecting httplib2<=0.12.0,>=0.8 (from apache-beam==2.14.0.dev0)
Collecting mock<3.0.0,>=1.0.1 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/e6/35/f187bdf23be87092bd0f1200d43d23076cee4d0dec109f195173fd3ebc79/mock-2.0.0-py2.py3-none-any.whl
Collecting oauth2client<4,>=2.0.1 (from apache-beam==2.14.0.dev0)
Requirement already satisfied: protobuf<4,>=3.5.0.post1 in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from apache-beam==2.14.0.dev0) (3.7.1)
Collecting pydot<1.3,>=1.2.0 (from apache-beam==2.14.0.dev0)
Collecting pytz>=2018.3 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/3d/73/fe30c2daaaa0713420d0382b16fbb761409f532c56bdcc514bf7b6262bb6/pytz-2019.1-py2.py3-none-any.whl
Collecting pyyaml<4.0.0,>=3.12 (from apache-beam==2.14.0.dev0)
Collecting avro<2.0.0,>=1.8.1 (from apache-beam==2.14.0.dev0)
Requirement already satisfied: futures<4.0.0,>=3.2.0 in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from apache-beam==2.14.0.dev0) (3.2.0)
Collecting pyvcf<0.7.0,>=0.6.8 (from apache-beam==2.14.0.dev0)
Collecting typing<3.7.0,>=3.6.0 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/cc/3e/29f92b7aeda5b078c86d14f550bf85cff809042e3429ace7af6193c3bc9f/typing-3.6.6-py2-none-any.whl
Collecting pyarrow<0.14.0,>=0.11.1 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/83/41/552ed611e2fe1ffca29df430a932426e6b5ce184a1fa26f5b954b0da4909/pyarrow-0.13.0-cp27-cp27mu-manylinux1_x86_64.whl
Collecting cachetools<4,>=3.1.0 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/39/2b/d87fc2369242bd743883232c463f28205902b8579cb68dcf5b11eee1652f/cachetools-3.1.0-py2.py3-none-any.whl
Collecting google-apitools<0.5.29,>=0.5.28 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/07/5e/3e04cb66f5ced9267a854184bb09863d85d199646ea8480fee26b4313a00/google_apitools-0.5.28-py2-none-any.whl
Collecting google-cloud-datastore<1.8.0,>=1.7.1 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/d0/aa/29cbcf8cf7d08ce2d55b9dce858f7c632b434cb6451bed17cb4275804217/google_cloud_datastore-1.7.4-py2.py3-none-any.whl
Collecting google-cloud-pubsub<0.40.0,>=0.39.0 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/c0/9a/4455b1c1450e9b912855b58ca6eee7a27ff1e9b52e4d98c243d93256f469/google_cloud_pubsub-0.39.1-py2.py3-none-any.whl
Collecting google-cloud-bigquery<1.7.0,>=1.6.0 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/b7/1b/2b95f2fefddbbece38110712c225bfb5649206f4056445653bd5ca4dc86d/google_cloud_bigquery-1.6.1-py2.py3-none-any.whl
Collecting google-cloud-core<0.30.0,>=0.28.1 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/0c/f2/3c225e7a69cb27d283b68bff867722bd066bc1858611180197f711815ea5/google_cloud_core-0.29.1-py2.py3-none-any.whl
Collecting google-cloud-bigtable<0.33.0,>=0.31.1 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/08/77/b468e209dbb0a6f614e6781f06a4894299a4c6167c2c525cc086caa7c075/google_cloud_bigtable-0.32.2-py2.py3-none-any.whl
Collecting proto-google-cloud-datastore-v1<=0.90.4,>=0.90.0 (from apache-beam==2.14.0.dev0)
Collecting googledatastore<7.1,>=7.0.1 (from apache-beam==2.14.0.dev0)
Collecting nose>=1.3.7 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/99/4f/13fb671119e65c4dce97c60e67d3fd9e6f7f809f2b307e2611f4701205cb/nose-1.3.7-py2-none-any.whl
Collecting numpy<2,>=1.14.3 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/e1/72/179a78b565ecf01fe98dab6417581d30acac15c2d93c49f93169ebea99b1/numpy-1.16.3-cp27-cp27mu-manylinux1_x86_64.whl
Collecting pandas<0.24,>=0.23.4 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/b7/e3/f52d484244105fa3d558ce8217a5190cd3d40536076bef66d92d01566325/pandas-0.23.4-cp27-cp27mu-manylinux1_x86_64.whl
Collecting parameterized<0.7.0,>=0.6.0 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/3a/49/75f6dadb09e2f8ace3cdffe0c99a04f1b98dff41fbf9e768665d8b469e29/parameterized-0.6.3-py2.py3-none-any.whl
Collecting pyhamcrest<2.0,>=1.9 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/9a/d5/d37fd731b7d0e91afcc84577edeccf4638b4f9b82f5ffe2f8b62e2ddc609/PyHamcrest-1.9.0-py2.py3-none-any.whl
Collecting tenacity<6.0,>=5.0.2 (from apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/6a/93/dfcf5b1b46ab29196274b78dcba69fab5e54b6dc303a7eed90a79194d277/tenacity-5.0.4-py2.py3-none-any.whl
Requirement already satisfied: six>=1.5.2 in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from grpcio<2,>=1.8->apache-beam==2.14.0.dev0) (1.12.0)
Requirement already satisfied: enum34>=1.0.4; python_version < "3.4" in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from grpcio<2,>=1.8->apache-beam==2.14.0.dev0) (1.1.6)
Collecting docopt (from hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
Collecting requests>=2.7.0 (from hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/51/bd/23c926cd341ea6b7dd0b2a00aba99ae0f828be89d72b2190f27c11d4b7fb/requests-2.22.0-py2.py3-none-any.whl
Collecting pbr>=0.11 (from mock<3.0.0,>=1.0.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/07/3e/22d1d35a4b51706ca3590c54359aeb5fa7ea60df46180143a3ea13d45f29/pbr-5.2.0-py2.py3-none-any.whl
Collecting funcsigs>=1; python_version < "3.3" (from mock<3.0.0,>=1.0.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/69/cb/f5be453359271714c01b9bd06126eaf2e368f1fddfff30818754b5ac2328/funcsigs-1.0.2-py2.py3-none-any.whl
Collecting pyasn1>=0.1.7 (from oauth2client<4,>=2.0.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/7b/7c/c9386b82a25115cccf1903441bba3cbadcfae7b678a20167347fa8ded34c/pyasn1-0.4.5-py2.py3-none-any.whl
Collecting pyasn1-modules>=0.0.5 (from oauth2client<4,>=2.0.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/91/f0/b03e00ce9fddf4827c42df1c3ce10c74eadebfb706231e8d6d1c356a4062/pyasn1_modules-0.2.5-py2.py3-none-any.whl
Collecting rsa>=3.1.4 (from oauth2client<4,>=2.0.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/02/e5/38518af393f7c214357079ce67a317307936896e961e35450b70fad2a9cf/rsa-4.0-py2.py3-none-any.whl
Requirement already satisfied: setuptools in <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/lib/python2.7/site-packages> (from protobuf<4,>=3.5.0.post1->apache-beam==2.14.0.dev0) (41.0.1)
Collecting pyparsing>=2.1.4 (from pydot<1.3,>=1.2.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/dd/d9/3ec19e966301a6e25769976999bd7bbe552016f0d32b577dc9d63d2e0c49/pyparsing-2.4.0-py2.py3-none-any.whl
Collecting fasteners>=0.14 (from google-apitools<0.5.29,>=0.5.28->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/18/bd/55eb2d6397b9c0e263af9d091ebdb756b15756029b3cededf6461481bc63/fasteners-0.15-py2.py3-none-any.whl
Collecting google-api-core[grpc]<2.0.0dev,>=1.6.0 (from google-cloud-datastore<1.8.0,>=1.7.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/32/df/1af46c943d13332e0f113b8d1478d9d466a39db5a2c9edf1e533b720421a/google_api_core-1.11.0-py2.py3-none-any.whl
Collecting grpc-google-iam-v1<0.12dev,>=0.11.4 (from google-cloud-pubsub<0.40.0,>=0.39.0->apache-beam==2.14.0.dev0)
Collecting google-resumable-media>=0.2.1 (from google-cloud-bigquery<1.7.0,>=1.6.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/e2/5d/4bc5c28c252a62efe69ed1a1561da92bd5af8eca0cdcdf8e60354fae9b29/google_resumable_media-0.3.2-py2.py3-none-any.whl
Collecting googleapis-common-protos<2.0dev,>=1.5.2 (from proto-google-cloud-datastore-v1<=0.90.4,>=0.90.0->apache-beam==2.14.0.dev0)
Collecting python-dateutil>=2.5.0 (from pandas<0.24,>=0.23.4->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/41/17/c62faccbfbd163c7f57f3844689e3a78bae1f403648a6afb1d0866d87fbb/python_dateutil-2.8.0-py2.py3-none-any.whl
Collecting monotonic>=0.6; python_version == "2.7" (from tenacity<6.0,>=5.0.2->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/ac/aa/063eca6a416f397bd99552c534c6d11d57f58f2e94c14780f3bbf818c4cf/monotonic-1.5-py2.py3-none-any.whl
Collecting urllib3!=1.25.0,!=1.25.1,<1.26,>=1.21.1 (from requests>=2.7.0->hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/39/ec/d93dfc69617a028915df914339ef66936ea976ef24fa62940fd86ba0326e/urllib3-1.25.2-py2.py3-none-any.whl
Collecting certifi>=2017.4.17 (from requests>=2.7.0->hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/60/75/f692a584e85b7eaba0e03827b3d51f45f571c2e793dd731e598828d380aa/certifi-2019.3.9-py2.py3-none-any.whl
Collecting chardet<3.1.0,>=3.0.2 (from requests>=2.7.0->hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/bc/a9/01ffebfb562e4274b6487b4bb1ddec7ca55ec7510b22e4c51f14098443b8/chardet-3.0.4-py2.py3-none-any.whl
Collecting idna<2.9,>=2.5 (from requests>=2.7.0->hdfs<3.0.0,>=2.1.0->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/14/2c/cd551d81dbe15200be1cf41cd03869a46fe7226e7450af7a6545bfc474c9/idna-2.8-py2.py3-none-any.whl
Collecting google-auth<2.0dev,>=0.4.0 (from google-api-core[grpc]<2.0.0dev,>=1.6.0->google-cloud-datastore<1.8.0,>=1.7.1->apache-beam==2.14.0.dev0)
  Using cached https://files.pythonhosted.org/packages/c5/9b/ed0516cc1f7609fb0217e3057ff4f0f9f3e3ce79a369c6af4a6c5ca25664/google_auth-1.6.3-py2.py3-none-any.whl
Installing collected packages: crcmod, dill, fastavro, docopt, urllib3, certifi, chardet, idna, requests, hdfs, httplib2, pbr, funcsigs, mock, pyasn1, pyasn1-modules, rsa, oauth2client, pyparsing, pydot, pytz, pyyaml, avro, pyvcf, typing, numpy, pyarrow, cachetools, monotonic, fasteners, google-apitools, googleapis-common-protos, google-auth, google-api-core, google-cloud-core, google-cloud-datastore, grpc-google-iam-v1, google-cloud-pubsub, google-resumable-media, google-cloud-bigquery, google-cloud-bigtable, proto-google-cloud-datastore-v1, googledatastore, nose, python-dateutil, pandas, parameterized, pyhamcrest, tenacity, apache-beam
  Running setup.py develop for apache-beam
Successfully installed apache-beam avro-1.9.0 cachetools-3.1.0 certifi-2019.3.9 chardet-3.0.4 crcmod-1.7 dill-0.2.9 docopt-0.6.2 fastavro-0.21.23 fasteners-0.15 funcsigs-1.0.2 google-api-core-1.11.0 google-apitools-0.5.28 google-auth-1.6.3 google-cloud-bigquery-1.6.1 google-cloud-bigtable-0.32.2 google-cloud-core-0.29.1 google-cloud-datastore-1.7.4 google-cloud-pubsub-0.39.1 google-resumable-media-0.3.2 googleapis-common-protos-1.6.0 googledatastore-7.0.2 grpc-google-iam-v1-0.11.4 hdfs-2.5.2 httplib2-0.12.0 idna-2.8 mock-2.0.0 monotonic-1.5 nose-1.3.7 numpy-1.16.3 oauth2client-3.0.0 pandas-0.23.4 parameterized-0.6.3 pbr-5.2.0 proto-google-cloud-datastore-v1-0.90.4 pyarrow-0.13.0 pyasn1-0.4.5 pyasn1-modules-0.2.5 pydot-1.2.4 pyhamcrest-1.9.0 pyparsing-2.4.0 python-dateutil-2.8.0 pytz-2019.1 pyvcf-0.6.8 pyyaml-3.13 requests-2.22.0 rsa-4.0 tenacity-5.0.4 typing-3.6.6 urllib3-1.25.2

> Task :sdks:python:apache_beam:testing:load_tests:run FAILED
<https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/local/lib/python2.7/site-packages/setuptools/dist.py>:472: UserWarning: Normalizing '2.14.0.dev' to '2.14.0.dev0'
  normalized_version,
running nosetests
running egg_info
writing requirements to apache_beam.egg-info/requires.txt
writing apache_beam.egg-info/PKG-INFO
writing top-level names to apache_beam.egg-info/top_level.txt
writing dependency_links to apache_beam.egg-info/dependency_links.txt
writing entry points to apache_beam.egg-info/entry_points.txt
reading manifest file 'apache_beam.egg-info/SOURCES.txt'
reading manifest template 'MANIFEST.in'
warning: no files found matching 'README.md'
warning: no files found matching 'NOTICE'
warning: no files found matching 'LICENSE'
writing manifest file 'apache_beam.egg-info/SOURCES.txt'
Failure: ImportError (No module named org) ... ERROR

======================================================================
ERROR: Failure: ImportError (No module named org)
----------------------------------------------------------------------
Traceback (most recent call last):
  File "<https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/local/lib/python2.7/site-packages/nose/loader.py",> line 407, in loadTestsFromName
    module = resolve_name(addr.module)
  File "<https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/build/gradleenv/1329484227/local/lib/python2.7/site-packages/nose/util.py",> line 312, in resolve_name
    module = __import__('.'.join(parts_copy))
ImportError: No module named org

----------------------------------------------------------------------
XML: <https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/sdks/python/nosetests.xml>
----------------------------------------------------------------------
Ran 1 test in 0.001s

FAILED (errors=1)

FAILURE: Build failed with an exception.

* Where:
Build file '<https://builds.apache.org/job/beam_LoadTests_Python_GBK_Dataflow_Batch/ws/src/sdks/python/apache_beam/testing/load_tests/build.gradle'> line: 52

* What went wrong:
Execution failed for task ':sdks:python:apache_beam:testing:load_tests:run'.
> error occurred

* 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 44s
4 actionable tasks: 4 executed

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

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_LoadTests_Python_GBK_Dataflow_Batch #6

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


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