You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2017/05/22 20:57:20 UTC

Build failed in Jenkins: beam_PostCommit_Java_JDK_Versions_Test » JDK 1.7 (latest),beam #17

See <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/17/display/redirect?page=changes>

Changes:

[mingmxu] update JavaDoc for BoundedWindow

[vikasrk] Triggers for Java SDK post submit tests

[robertwb] Deprecate <pipeline>.options usage

[lcwik] Remove Coder.asCloudObject and related methods

[altay] Updating Dataflow API protos and client

[tgroh] Add Additional CloudObjectTranslators

[kirpichov] Removed coder and parseFn from PubsubIO.Read

[kirpichov] Removed coder and formatFn from PubsubIO.Write

[kirpichov] Introduces read/writePubsubMessages

[klk] Use LinkedHashMap for step contexts in BaseExecutionContext

[dhalperi] Remove IoChannelUtils from PackageUtil

[klk] Use Thread context ClassLoader as parent in AvroCoderTest

[dhalperi] [BEAM-59] FileChecksumMatcherTest: switch from IOChannelUtils to java

[tgroh] Mark all PCollectionView methods internal

[lcwik] [BEAM-1871] Move GCP specific serialization CloudObject and supporting

[tgroh] Reduce visibility of DirectRunner classes

[altay] Retry on correct error codes for datastoreio

[robertwb] Try PTransform-based coder inference before using fallback coder.

[robertwb] Fix coder inference ambiguity in CombineFnsTest.

[klk] Remove job name usages from BigQueryIO at pipeline construction time

[kirpichov] Fully general dynamic tables (including schemas) in BigQueryIO.

[kirpichov] Fixes PubsubIO.Write translation in Dataflow runner

[dhalperi] Convert WriteFiles/FileBasedSink from IOChannelFactory to FileSystems

[tgroh] Inline TypedPValue

[lcwik] [BEAM-2157] Fix HDFS Test That Failed in Other JDK Versions

[kirpichov] Provides a default coder for PubsubMessage

[kirpichov] Moves PubsubMessage to upper level and renames payload

[klk] BigQueryIO: Remove tempLocation usage at pipeline construction time

[dhalperi] Removal of Aggregator class. Also removal from comments.

[klk] Annotate internal methods of PCollection

[klk] Annotate internal pieces of sdks.transforms

[klk] Tighten access control and internal annotations for triggers

[klk] The transforms.reflect package is not for users

[klk] Annotate internal-only bits of Java sdk.runners

[klk] Tighten access in sdk.options

[klk] Annotate internal methods on Pipeline

[lcwik] [BEAM-2165] Update Apex to support serializing/deserializing custom user

[lcwik] [BEAM-2165] Update Dataflow to support serializing/deserializing custom

[lcwik] [BEAM-2165] Update Flink to support serializing/deserializing custom

[lcwik] [BEAM-1871] Migrate ReleaseInfo away from Google API client GenericJson

[dhalperi] DataflowRunner: integration test GCP-IO

[lcwik] [BEAM-1491]Identify HADOOP_CONF_DIR(or YARN_CONF_DIR) environment

[lcwik] Split Coder's encode/decode methods into two methods depending on

[dhalperi] [BEAM-2162] Add logging to long BigQuery jobs

[tgroh] Use BinaryCombineLongFn in GroupIntoBatches

[altay] [BEAM-2152] Remove gcloud auth as application default credentials does

[dhalperi] AvroIOTest: stop using IOChannelUtils, remove invalid test

[dhalperi] DataflowRunner: switch from IOChannels to FileSystems for creating files

[dhalperi] DataflowPipelineOptions: use FileSystems, not IOChannelUtils, to resolve

[dhalperi] Stop registering IOChannelFactories in SDK harness, runners, tests

[dhalperi] FileSystems: add match(String) for single spec

[dhalperi] WriteWithShardingFactoryTest: switch to FileSystems

[dhalperi] ReadTranslator: remove outdated comment

[dhalperi] TFRecordIO: switch to FileSystems from IOChannelUtils

[lcwik] Remove POutput#recordAsOutput

[robertwb] One more TaggedOutput name change.

[dhalperi] Update JavaDoc of checkpoint, and expose `enable.auto.commit` for more

[lcwik] Use CloudObject encodings in the Beam Fn Harness

[aviemzur] [BEAM-1763] Verify PAssert execution in runners which support metrics.

[aviemzur] [BEAM-1726] Fix empty side inputs in Flink Streaming Runner

[aviemzur] [BEAM-1726] Fix RuntimeException throwing in FlinkStateInternals

[aviemzur] [BEAM-1726] Fix Flatten with input copies in Flink Streaming Runner

[aviemzur] [BEAM-1763] Replace usage of PipelineRule with TestPipeline in Spark

[dhalperi] GCP-IO: manage versions in top level pom

[dhalperi] Remove IOChannelUtil/Factory from BigQueryIO

[klk] Eliminate Pipeline.getOptions

[robertwb] Cleanup old cython files before testing again

[klk] [BEAM-1727] Add align and offset to Timer

[klk] Fix initial watermark of DoFnOperator in Flink runner

[dhalperi] [BEAM-59] Remove IOChannelUtils, IOChannelFactory

[dhalperi] Move thrown.expect to correct place

[tgroh] Note when checkpoints may be committed.

[klk] Activate WindowedWordCountIT on Apex runner

[tgroh] Split StartBundleContext and FinishBundleContext

[kirpichov] [BEAM-2170] PubsubMessageWithAttributesCoder should not NPE on messages

[kirpichov] Makes PubsubMessagePayloadOnlyCoder not require whole-stream context

[kirpichov] Moves coder choice into PubsubSource

[klk] Move Java sdk.util.state to sdk.state

[klk] Add @Internal and @Experimental to state package

[klk] Move user-facing timer-related classes out of util

[klk] Mark TimeDomain experimental alongside Timers; improve javadoc

[klk] Move WindowingStrategy from util to values

[klk] Move PathValidator adjacent to other filesystem bits

[klk] Move SideInputReader to runners/core-java

[klk] Move Reshuffle and ReshuffleTrigger out of util

[klk] Move ValueWithRecordId to sdk.values, annotated

[klk] Move some PCollectionView bits out of util

[klk] Update Dataflow worker to 20170504-2

[davor] [BEAM-2144] Remove transform.reflect and utils from Javadocs

[tgroh] Update expectation in ProcessBundleHandlerTest

[dhalperi] [BEAM-1871] Move out test only utilities used only in examples/java out

[dhalperi] Revert "This closes #2905"

[klk] Adjust error message expectation in DoFnSignaturesTest

[klk] No parallelism for Apex WindowedWordCountIT

[aljoscha.krettek] [BEAM-1862] SplittableDoFnOperator should close the

[thw] [BEAM-2180] update Apex version to 3.6.0

[dhalperi] [BEAM-2016] Delete HdfsFileSource & Sink

[tgroh] Run Optimize Imports on the Repository

[tgroh] Move AppliedPTransform into the Runners package

[tgroh] Convert Coder into an Abstract Static Class

[dhalperi] [BEAM-59] Fully delete IOChannelUtils

[github] [BEAM-2141] disable beam_PerformanceTests_Dataflow

[klk] Move PipelineRunner to toplevel sdk package (automated refactor)

[klk] Exclude sdk.runners from javadoc

[klk] Javadoc that the sdk.runners package is internal

[altay] Use uuid for temp directory

[tgroh] Re-add AtomicCoder

[tgroh] Add default implementations of Coder methods to Coder

[tgroh] Reparent many Coders to Atomic or StructuredCoder

[tgroh] Make CustomCoder extend Coder directly

[altay] Metrics are queriable from Python SDK

[dhalperi] Archetypes: fix build order

[dhalperi] Examples: allow java8 bytecode since the examples are java8

[chamikara] [BEAM-1585] Filesystems should be picked using the provided scheme

[davor] [BEAM-2165] Update Spark to support serializing/deserializing custom

[dhalperi] Fix merge bug in SparkRuntimeContext

[lcwik] [BEAM-2174] Update CoderRegistry to allow creating coders through

[lcwik] [BEAM-2187] Fix build break in SparkRuntimeContextTest

[davor] [maven-release-plugin] prepare branch release-2.0.0

[davor] [maven-release-plugin] prepare for next development iteration

[davor] Update archetype reference after changing version identifier

[davor] [BEAM-806] Use filtering for the version of the reference test project

[davor] PR polish: move testResources section from all-archetypes level to

[davor] Fix default temp location for DataflowRunner

[dhalperi] [BEAM-2181] Upgrade to Bigtable 0.9.6.2

[altay] Update python dataflow worker

[aviemzur] [BEAM-1672] Make MetricsContainers accumulable.

[aviemzur] [BEAM-1672] Use Accumulable MetricsContainers in Spark runner.

[aviemzur] [BEAM-1672] Use Accumulable MetricsContainers in Flink runner.

[klk] Register the TestDataflowRunner via registrar

[klk] Move TestDataflowRunner into dataflow package

[lcwik] Remove context from size estimate operations.

[thw] [BEAM-831] ParDo Fusion of Apex Runner

[thw] [BEAM-831] Fix chaining, add test. closes #2216

[lcwik] Remove uses of context in coder size estimation calls.

[altay] Fixing typo in datastore_wordcount.py

[robertwb] Only cythonize files within apache_beam

[aljoscha.krettek] [BEAM-1723] deduplication of UnboundedSource in Flink runner

[dhalperi] [BEAM-2190] pom.xml: do a better job of dependency management

[dhalperi] [BEAM-2212] FileBasedSource: improve message when logging.

[dhalperi] [BEAM-2212] FileBasedSource: refactor to remove uses of

[tgroh] Convert Executor Services to use Daemon Threads

[altay] [BEAM-2206] Move pipelineOptions into options modules

[kirpichov] TableDescription is allowed to be null.

[kirpichov] Shortens PubsubIO names for reading/writing messages.

[altay] Remove apex README.md. This information is already in the website in

[altay] Remove readme.md files that are covered in web site

[robertwb] [BEAM-2224] Fix temp file management on Windows.

[kirpichov] [BEAM-2154] More scalable dynamic BigQueryIO.Write

[lcwik] Use guava Base64 encoding instead of google api client

[lcwik] Remove google api BackOff usage from sdks/core

[dhalperi] [BEAM-2211] DataflowRunner: remove validation of file read/write paths

[lcwik] Remove explicit used of nested contexts.

[lcwik] Remove contexts from coders where they'll never be used.

[lcwik] automated context removal or redirection

[lcwik] get it compiling

[lcwik] Remove en/decodeOuter and default encode/decode methods.

[lcwik] fixup! Swap to use encode/decode in anonymous inner class coder and

[lcwik] Reviewer comments + a couple of extra fixes. All compiles.

[lcwik] lint error

[lcwik] checkstyle

[lcwik] Use latest dataflow worker.

[lcwik] Explicitly mark Coder context as experimental as well as deprecated.

[robertwb] Don't log full exception traceback in direct runner.

[robertwb] [BEAM-2184] Rename OutputTimeFn to TimestampCombiner.

[robertwb] [BEAM-1925] validate DoFn at pipeline creation time

[staslevin] [BEAM-2095] Made SourceRDD hasNext idempotent

[robertwb] Actually run after-count tests.

[altay] [BEAM-1283] Finish bundle should only emit windowed values

[altay] Remove sdk & example README.md that are covered in web site

[dhalperi] [BEAM-2211] Move PathValidator into GCP-Core

[dhalperi] Handle Errors in the DirectRunner

[dhalperi] Shade Dependencies of the DirectRunner

[altay] Remove old imports meant for backwards compatibility

[kirpichov] KafkaIO API clean up

[kirpichov] KafkaIO javadoc fixups

[dhalperi] [BEAM-2229] GcsFileSystem: handle empty files

[tgroh] Make PCollectionViewWindow package private

[klk] Revise javadoc for sdk, state, options, annotations, window, (and misc)

[altay] Remove templates from wordcount example

[altay] Remove hadoop io readme

[tgroh] Shade JSR305 in the DirectRunner

[ccy] Update Apache Beam Python version to 2.1.0.dev

[davor] Register TestSparkPipelineOptions only in src/test to avoid hard

[davor] Add per-runner profile to Java 8 examples

[altay] Remove trailing whitespace

[davor] Shade dependencies in sdks/core

[davor] Fix checkstyle error

[davor] Include 'sun.reflect' in GcpCoreApiSurfaceTest

[altay] [BEAM-2236] Move test utilities out of python core

[tgroh] Mark PValue and PValueBase Internal

[chamikara] Mark PipelineVisitor and AppliedPTransform as internal.

[chamikara] Renames some python classes and functions that were unnecessarily

[altay] Remove Readme files.

[klk] Remove Timer.cancel() from user-facing API

[dhalperi] [BEAM-2211] Delete deprecated NoopPathValidator

[tgroh] Improve DirectRunner Javadoc

[tgroh] Update Coder Documentation

[tgroh] Remove verifyDeterministic from StructuredCoder

[altay] Use text output for first two mobile gaming examples

[dhalperi] [BEAM-2249] Correctly handle partial reads in AvroSource

[altay] [BEAM-2250] remove experimental and internal things from pydoc

[kirpichov] Renames FileBasedSink inner classes

[kirpichov] Implement dynamic-sharding for windowed file outputs, and add an

[kirpichov] Simpler code for setting shard numbers on results in FileBasedSink

[kirpichov] Splits WriteBundles into windowed/unwindowed versions

[kirpichov] Adds dependency on findbugs to examples/java

[robertwb] [BEAM-2240] Always augment exception with step name.

[lcwik] [BEAM-2242] Ensure that jars are shaded correctly by running the jar

[klk] Allow any throwable in PAssert to constitute adequate failure

[klk] TestDataflowRunner: throw AssertionError only when assertion known

[klk] Re-enable UsesTimersInParDo tests in Dataflow runner

[vikasrk] Fix a typo in TestDataflowRunnerTest

[vikasrk] Skip generating empty jars for parent poms

[lcwik] Update SDK Coders to return the Empty List from getCoderArguments

[klk] Correct javadoc for mobile gaming examples

[dhalperi] [BEAM-2244] Move details of Metrics to Runners Core

[jasonkuster] bump time of precommits

[dhalperi] [BEAM-2150] Relax regex to support wildcard globbing for GCS

[borisa.zivkovic] Add support for local execution to PubsubIO using the google cloud

[dhalperi] minor typo fix in comment

[lcwik] Remove protobuf and http-client dependency from

[altay] Add internal usage only comments to util/

[altay] [BEAM-1345] Mark windowed value as experimental

[jbonofre] [BEAM-2179] Archetype generate-sources.sh cleanup the existing sources

[dhalperi] [BEAM-2260] Improve construction-time errors for Text and AvroIO

[altay] Mark internal modules in python datastoreio

[altay] [BEAM-1345] Clearly delineate public API in apache_beam/options

[robertwb] [BEAM-1345] Mark Pipeline as public.

[robertwb] [BEAM-1345] Clearly delineate public api in runners package.

[robertwb] [BEAM-1345] Clearly delineate public api in apache_beam/coders.

[robertwb] [BEAM-1340] Adds __all__ tags to classes in package apache_beam/io.

[robertwb] Add __all__ tags to modules in package apache_beam/testing

[vikasrk] fix lint error in fake_datastore.py

[tgroh] Use a consistent calculation for GC Time

[lcwik] [BEAM-2256] Add the last previous range filter

[robertwb] [BEAM-1340] Add __all__ tags to modules in package

[altay] Add internal comments to metrics

[robertwb] [BEAM-1345] Annotate public members of pvalue.

[robertwb] [BEAM-1345] Mark apache_beam/internal as internal.

[robertwb] [BEAM-1345] Clearly delineate public api in apache_beam/typehints.

[robertwb] Move assert_that, equal_to, is_empty to apache_beam.testing.util

[altay] Remove some internal details from the public API.

[dhalperi] Don't deploy jdk1.8-tests module

[robertwb] Fix due to GBKO name change.

[sourabhbajaj] Remove unused test data

[tgroh] Enable SerializableCoder to Serialize with Generic Types

[altay] Rename filesink to filebasedsink

[lcwik] Mark More values methods Internal

[jbonofre] [BEAM-2153] Move connection management in JmsIO.write() to

[kirpichov] BigtableIO should use AutoValue for read and write

[dhalperi] [BEAM-2277] Fix URI_SCHEME_PATTERN in FileSystems

[davor] [BEAM-2279] Add HDFS support to Spark runner profiles in archetypes and

[dhalperi] Remove '/' entirely from determining FileSystem scheme

[dhalperi] [BEAM-2277] Add ResourceIdTester and test existing ResourceId

[dhalperi] Mark FileSystem and related as Experimental

[dhalperi] [BEAM-2277] HadoopFileSystem: normalize implementation

[dhalperi] Rename FileSystems.setDefaultConfigInWorkers

[dhalperi] Fix shading of guava testlib

[altay] internal comments

[dhalperi] [BEAM-2279] Fix archetype breakages

[dhalperi] [BEAM-2290] Fix issue where timestamps weren't set when using

[tgroh] Reduce Log Level of PubsubUnboundedSource

[github] readAvros should't have proto Message upper bound

[lcwik] Fix GcsResourceIdTest in postcommits

[altay] Moving the data file for trigger tests to testing/data

[altay] Remove "Dataflow" from apache_beam __init__.py file

[lcwik] [BEAM-2299] Run maven install on Windows machine for build/test coverage

[sourabhbajaj] Fix documentation for the shard_template_name

[kirpichov] ApexRunner SDF support

[altay] Use built-in cmp python function in comparing datastore paths

[altay] Adding support for subnetwork in Python Pipelineoptions

[tgroh] Improve Pruning performed by the DirectRunnerApiSurfaceTest

[kirpichov] Bump Dataflow containers to 0512

[kirpichov] Removes OldDoFn and its kin from runners-core

[kirpichov] Fixes an accidentally found bug in SimpleDoFnRunner

[dhalperi] [TRIVIAL] runners-core: delete placeholder

[tgroh] Translate a Pipeline in SdkComponents

[klk] Use stable naming strategy for ByteBuddy invokers

[klk] Restore non-recursive globs in GcsUtil

[dhalperi] [BEAM-1702] Document how to use BigtableIO with local emulator

[klk] [BEAM-659] WindowFn#isCompatible should provide a meaningful reason

[kirpichov] Remove incorrect `Message` bound on writeAvros

[tgroh] Add ParDos

[kirpichov] Splits SplittableParDo into a core-construction part and a KWI-related

[dhalperi] [BEAM-2318] Ensure that tables that don't exist are not created

[iemejia] [BEAM-2391] Clone Scan in HBaseReader

[lcwik] [BEAM-2252] Use pluginManagement instead of redefining

[altay] update dataflow python container

[klk] [BEAM-2164] Fix generate-sources.sh if directory contains space

[klk] Move snappy-java version to dependencyManagement

[kirpichov] Comply with byte limit for Datastore Commit.

[kirpichov] Make the large entities test neater.

[kirpichov] End-to-end test for large entity writes.

[lcwik] [BEAM-1345] Remove FileSystems.setDefaultConfigInWorkers since Dataflow

[lcwik] [BEAM-2293] Rename Top.{Largest,Smallest=>Natural,Reversed}

[lcwik] [BEAM-2253] Use resource transformer plugin to use versions defined in

[lcwik] [BEAM-2334] Fix OutOfMemoryError

[klk] Add TransformPayloadTranslatorRegistrar

[tgroh] Fix GroupAlsoByWindowEvaluatorFactory doc

[klk] Minor touch-ups to new BoundedWindow javadoc

[tgroh] Remove Unused DoFnInfo methods

[tgroh] Extract the Main Input PCollection in ParDos

[tgroh] Cleanup k8s scripts naming & don't create insecure svc by default

------------------------------------------
[...truncated 1.05 MB...]
2017-05-22\T\20:45:46.181 [INFO] Excluding io.grpc:grpc-okhttp:jar:1.2.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.squareup.okhttp:okhttp:jar:2.5.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.squareup.okio:okio:jar:1.6.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding io.grpc:grpc-protobuf:jar:1.2.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.google.protobuf:protobuf-java-util:jar:3.2.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.google.code.gson:gson:jar:2.7 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding io.grpc:grpc-protobuf-lite:jar:1.2.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding io.grpc:grpc-protobuf-nano:jar:1.2.0 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.google.protobuf.nano:protobuf-javanano:jar:3.0.0-alpha-5 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.google.cloud.bigtable:bigtable-protos:jar:0.9.6.2 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding com.google.cloud.bigtable:bigtable-client-core:jar:0.9.6.2 from the shaded jar.
2017-05-22\T\20:45:46.181 [INFO] Excluding commons-logging:commons-logging:jar:1.2 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.auth:google-auth-library-appengine:jar:0.6.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.appengine:appengine-api-1.0-sdk:jar:1.9.34 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding io.dropwizard.metrics:metrics-core:jar:3.1.2 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.api.grpc:grpc-google-common-protos:jar:0.1.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding io.netty:netty-tcnative-boringssl-static:jar:1.1.33.Fork26 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.api-client:google-api-client:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.oauth-client:google-oauth-client:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.apis:google-api-services-bigquery:jar:v2-rev295-1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.code.findbugs:jsr305:jar:3.0.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.http-client:google-http-client:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.httpcomponents:httpclient:jar:4.0.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.httpcomponents:httpcore:jar:4.0.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding commons-codec:commons-codec:jar:1.3 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.cloud.bigdataoss:util:jar:1.4.5 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.api-client:google-api-client-java6:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.api-client:google-api-client-jackson2:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.oauth-client:google-oauth-client-java6:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.auth:google-auth-library-oauth2-http:jar:0.6.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.auth:google-auth-library-credentials:jar:0.6.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.avro:avro:jar:1.8.1 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.codehaus.jackson:jackson-core-asl:jar:1.9.13 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.codehaus.jackson:jackson-mapper-asl:jar:1.9.13 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.thoughtworks.paranamer:paranamer:jar:2.7 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.tukaani:xz:jar:1.5 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.apis:google-api-services-pubsub:jar:v1-rev10-1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Including com.google.guava:guava:jar:20.0 in the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.cloud.datastore:datastore-v1-proto-client:jar:1.4.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.http-client:google-http-client-protobuf:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.http-client:google-http-client-jackson:jar:1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.cloud.datastore:datastore-v1-protos:jar:1.3.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding joda-time:joda-time:jar:2.4 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.slf4j:slf4j-api:jar:1.7.14 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.slf4j:slf4j-jdk14:jar:1.7.14 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.beam:beam-sdks-common-runner-api:jar:2.1.0-SNAPSHOT from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.beam:beam-runners-core-construction-java:jar:2.1.0-SNAPSHOT from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding org.apache.beam:beam-runners-google-cloud-dataflow-java:jar:2.1.0-SNAPSHOT from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.apis:google-api-services-dataflow:jar:v1b3-rev196-1.22.0 from the shaded jar.
2017-05-22\T\20:45:46.182 [INFO] Excluding com.google.apis:google-api-services-clouddebugger:jar:v2-rev8-1.22.0 from the shaded jar.
2017-05-22\T\20:45:49.322 [INFO] Replacing original artifact with shaded artifact.
2017-05-22\T\20:45:49.323 [INFO] Replacing <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/beam-examples-java-2.1.0-SNAPSHOT.jar> with <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/beam-examples-java-2.1.0-SNAPSHOT-shaded.jar>
2017-05-22\T\20:45:49.323 [INFO] Replacing original test artifact with shaded test artifact.
2017-05-22\T\20:45:49.323 [INFO] Replacing <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/beam-examples-java-2.1.0-SNAPSHOT-tests.jar> with <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/beam-examples-java-2.1.0-SNAPSHOT-shaded-tests.jar>
2017-05-22\T\20:45:49.323 [INFO] Dependency-reduced POM written at: <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/dependency-reduced-pom.xml>
2017-05-22\T\20:45:49.442 [INFO] 
2017-05-22\T\20:45:49.442 [INFO] --- maven-failsafe-plugin:2.20:integration-test (default) @ beam-examples-java ---
2017-05-22\T\20:45:49.446 [INFO] Failsafe report directory: <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/failsafe-reports>
2017-05-22\T\20:45:49.447 [INFO] parallel='all', perCoreThreadCount=true, threadCount=4, useUnlimitedThreads=false, threadCountSuites=0, threadCountClasses=0, threadCountMethods=0, parallelOptimized=true
2017-05-22\T\20:45:49.448 [INFO] 
2017-05-22\T\20:45:49.448 [INFO] -------------------------------------------------------
2017-05-22\T\20:45:49.448 [INFO]  T E S T S
2017-05-22\T\20:45:49.448 [INFO] -------------------------------------------------------
2017-05-22\T\20:56:47.241 [INFO] Running org.apache.beam.examples.cookbook.BigQueryTornadoesIT
2017-05-22\T\20:56:47.252 [INFO] Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 652.95 s - in org.apache.beam.examples.cookbook.BigQueryTornadoesIT
2017-05-22\T\20:56:47.252 [INFO] Running org.apache.beam.examples.WindowedWordCountIT
2017-05-22\T\20:56:47.264 [ERROR] Tests run: 3, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 511.7 s <<< FAILURE! - in org.apache.beam.examples.WindowedWordCountIT
2017-05-22\T\20:56:47.264 [ERROR] testWindowedWordCountInBatchDynamicSharding(org.apache.beam.examples.WindowedWordCountIT)  Time elapsed: 230.259 s  <<< ERROR!
java.lang.RuntimeException: Failed to create a workflow job: (12d9d3cf61b1bb25): The workflow could not be created. Causes: (f7d26b9e935b516b): Too many running jobs. Project apache-beam-testing is running 25 jobs and project limit for active jobs is 25. To fix this, cancel an existing workflow via the UI, wait for a workflow to finish or contact dataflow-feedback@google.com to request an increase in quota.
	at org.apache.beam.runners.dataflow.DataflowRunner.run(DataflowRunner.java:613)
	at org.apache.beam.runners.dataflow.TestDataflowRunner.run(TestDataflowRunner.java:97)
	at org.apache.beam.runners.dataflow.TestDataflowRunner.run(TestDataflowRunner.java:89)
	at org.apache.beam.runners.dataflow.TestDataflowRunner.run(TestDataflowRunner.java:54)
	at org.apache.beam.sdk.Pipeline.run(Pipeline.java:295)
	at org.apache.beam.sdk.Pipeline.run(Pipeline.java:281)
	at org.apache.beam.examples.WindowedWordCount.main(WindowedWordCount.java:215)
	at org.apache.beam.examples.WindowedWordCountIT.testWindowedWordCountPipeline(WindowedWordCountIT.java:185)
	at org.apache.beam.examples.WindowedWordCountIT.testWindowedWordCountInBatchDynamicSharding(WindowedWordCountIT.java:93)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:606)
	at org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:50)
	at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:12)
	at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:47)
	at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:17)
	at org.junit.rules.TestWatcher$1.evaluate(TestWatcher.java:55)
	at org.junit.rules.RunRules.evaluate(RunRules.java:20)
	at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:325)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:78)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:57)
	at org.junit.runners.ParentRunner$3.run(ParentRunner.java:290)
	at org.apache.maven.surefire.junitcore.pc.Scheduler$1.run(Scheduler.java:393)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:471)
	at java.util.concurrent.FutureTask.run(FutureTask.java:262)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
	at java.lang.Thread.run(Thread.java:745)
Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException: 429 Too Many Requests
{
  "code" : 429,
  "errors" : [ {
    "domain" : "global",
    "message" : "(12d9d3cf61b1bb25): The workflow could not be created. Causes: (f7d26b9e935b516b): Too many running jobs. Project apache-beam-testing is running 25 jobs and project limit for active jobs is 25. To fix this, cancel an existing workflow via the UI, wait for a workflow to finish or contact dataflow-feedback@google.com to request an increase in quota.",
    "reason" : "rateLimitExceeded"
  } ],
  "message" : "(12d9d3cf61b1bb25): The workflow could not be created. Causes: (f7d26b9e935b516b): Too many running jobs. Project apache-beam-testing is running 25 jobs and project limit for active jobs is 25. To fix this, cancel an existing workflow via the UI, wait for a workflow to finish or contact dataflow-feedback@google.com to request an increase in quota.",
  "status" : "RESOURCE_EXHAUSTED"
}
	at com.google.api.client.googleapis.json.GoogleJsonResponseException.from(GoogleJsonResponseException.java:146)
	at com.google.api.client.googleapis.services.json.AbstractGoogleJsonClientRequest.newExceptionOnError(AbstractGoogleJsonClientRequest.java:113)
	at com.google.api.client.googleapis.services.json.AbstractGoogleJsonClientRequest.newExceptionOnError(AbstractGoogleJsonClientRequest.java:40)
	at com.google.api.client.googleapis.services.AbstractGoogleClientRequest$1.interceptResponse(AbstractGoogleClientRequest.java:321)
	at com.google.api.client.http.HttpRequest.execute(HttpRequest.java:1065)
	at com.google.api.client.googleapis.services.AbstractGoogleClientRequest.executeUnparsed(AbstractGoogleClientRequest.java:419)
	at com.google.api.client.googleapis.services.AbstractGoogleClientRequest.executeUnparsed(AbstractGoogleClientRequest.java:352)
	at com.google.api.client.googleapis.services.AbstractGoogleClientRequest.execute(AbstractGoogleClientRequest.java:469)
	at org.apache.beam.runners.dataflow.DataflowClient.createJob(DataflowClient.java:61)
	at org.apache.beam.runners.dataflow.DataflowRunner.run(DataflowRunner.java:600)
	... 28 more

2017-05-22\T\20:56:47.265 [INFO] Running org.apache.beam.examples.WordCountIT
2017-05-22\T\20:56:47.266 [INFO] Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 452.596 s - in org.apache.beam.examples.WordCountIT
2017-05-22\T\20:56:47.774 [INFO] 
2017-05-22\T\20:56:47.774 [INFO] Results:
2017-05-22\T\20:56:47.774 [INFO] 
2017-05-22\T\20:56:47.774 [ERROR] Errors: 
2017-05-22\T\20:56:47.774 [ERROR]   WindowedWordCountIT.testWindowedWordCountInBatchDynamicSharding:93->testWindowedWordCountPipeline:185 » Runtime
2017-05-22\T\20:56:47.774 [INFO] 
2017-05-22\T\20:56:47.774 [ERROR] Tests run: 5, Failures: 0, Errors: 1, Skipped: 0
2017-05-22\T\20:56:47.774 [INFO] 
2017-05-22\T\20:56:47.778 [INFO] 
2017-05-22\T\20:56:47.778 [INFO] --- maven-dependency-plugin:3.0.0:analyze-only (default) @ beam-examples-java ---
2017-05-22\T\20:56:47.879 [INFO] No dependency problems found
2017-05-22\T\20:56:47.879 [INFO] 
2017-05-22\T\20:56:47.879 [INFO] --- maven-failsafe-plugin:2.20:verify (default) @ beam-examples-java ---
2017-05-22\T\20:56:47.879 [INFO] Failsafe report directory: <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/failsafe-reports>
2017-05-22\T\20:56:47.884 [INFO] ------------------------------------------------------------------------
2017-05-22\T\20:56:47.884 [INFO] Reactor Summary:
2017-05-22\T\20:56:47.884 [INFO] 
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Parent .............................. SUCCESS [ 27.428 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Build Tools ......... SUCCESS [  8.427 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs ................................ SUCCESS [  0.571 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Common ...................... SUCCESS [  0.618 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Common :: Fn API ............ SUCCESS [ 14.112 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Common :: Runner API ........ SUCCESS [  3.316 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java ........................ SUCCESS [  0.760 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Core ................ SUCCESS [02:10 min]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO .................. SUCCESS [  0.461 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Common ........ SUCCESS [  3.752 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners ............................. SUCCESS [  0.578 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Core Construction Java ... SUCCESS [ 20.410 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Core Java ................ SUCCESS [ 35.609 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Direct Java .............. SUCCESS [03:51 min]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Elasticsearch . SUCCESS [ 36.288 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions .......... SUCCESS [  0.528 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions :: Google Cloud Platform Core SUCCESS [ 35.193 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions :: Protobuf SUCCESS [ 13.662 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Google Cloud Platform SUCCESS [ 59.215 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Hadoop Common . SUCCESS [ 13.727 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Hadoop File System SUCCESS [ 30.828 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Hadoop ........ SUCCESS [  3.500 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Hadoop :: input-format SUCCESS [ 11.856 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: HBase ......... SUCCESS [01:18 min]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Google Cloud Dataflow .... SUCCESS [06:36 min]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: JDBC .......... SUCCESS [ 28.175 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: JMS ........... SUCCESS [ 13.786 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Kafka ......... SUCCESS [ 31.717 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: Kinesis ....... SUCCESS [ 19.037 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: MongoDB ....... SUCCESS [ 37.840 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: MQTT .......... SUCCESS [ 16.846 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: IO :: XML ........... SUCCESS [ 23.439 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Maven Archetypes .... SUCCESS [  0.573 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Maven Archetypes :: Starter SUCCESS [ 12.062 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Examples ............................ SUCCESS [  0.452 s]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Examples :: Java .................... FAILURE [11:19 min]
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Maven Archetypes :: Examples SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions :: Jackson SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions :: Join library SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Extensions :: Sorter  SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Flink .................... SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: Runners :: Spark .................... SKIPPED
2017-05-22\T\20:56:47.884 [INFO] Apache Beam :: SDKs :: Java :: Aggregated Javadoc .. SKIPPED
2017-05-22\T\20:56:47.884 [INFO] ------------------------------------------------------------------------
2017-05-22\T\20:56:47.884 [INFO] BUILD FAILURE
2017-05-22\T\20:56:47.884 [INFO] ------------------------------------------------------------------------
2017-05-22\T\20:56:47.884 [INFO] Total time: 33:45 min
2017-05-22\T\20:56:47.884 [INFO] Finished at: 2017-05-22T20:56:47+00:00
2017-05-22\T\20:56:48.641 [INFO] Final Memory: 205M/1388M
2017-05-22\T\20:56:48.641 [INFO] ------------------------------------------------------------------------
2017-05-22\T\20:56:48.642 [ERROR] Failed to execute goal org.apache.maven.plugins:maven-failsafe-plugin:2.20:verify (default) on project beam-examples-java: There are test failures.
2017-05-22\T\20:56:48.642 [ERROR] 
2017-05-22\T\20:56:48.642 [ERROR] Please refer to <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/failsafe-reports> for the individual test results.
2017-05-22\T\20:56:48.642 [ERROR] Please refer to dump files (if any exist) [date]-jvmRun[N].dump, [date].dumpstream and [date]-jvmRun[N].dumpstream.
2017-05-22\T\20:56:48.642 [ERROR] -> [Help 1]
org.apache.maven.lifecycle.LifecycleExecutionException: Failed to execute goal org.apache.maven.plugins:maven-failsafe-plugin:2.20:verify (default) on project beam-examples-java: There are test failures.

Please refer to <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/failsafe-reports> for the individual test results.
Please refer to dump files (if any exist) [date]-jvmRun[N].dump, [date].dumpstream and [date]-jvmRun[N].dumpstream.
	at org.apache.maven.lifecycle.internal.MojoExecutor.execute(MojoExecutor.java:212)
	at org.apache.maven.lifecycle.internal.MojoExecutor.execute(MojoExecutor.java:153)
	at org.apache.maven.lifecycle.internal.MojoExecutor.execute(MojoExecutor.java:145)
	at org.apache.maven.lifecycle.internal.LifecycleModuleBuilder.buildProject(LifecycleModuleBuilder.java:116)
	at org.apache.maven.lifecycle.internal.LifecycleModuleBuilder.buildProject(LifecycleModuleBuilder.java:80)
	at org.apache.maven.lifecycle.internal.builder.singlethreaded.SingleThreadedBuilder.build(SingleThreadedBuilder.java:51)
	at org.apache.maven.lifecycle.internal.LifecycleStarter.execute(LifecycleStarter.java:128)
	at org.apache.maven.DefaultMaven.doExecute(DefaultMaven.java:307)
	at org.apache.maven.DefaultMaven.doExecute(DefaultMaven.java:193)
	at org.apache.maven.DefaultMaven.execute(DefaultMaven.java:106)
	at org.apache.maven.cli.MavenCli.execute(MavenCli.java:862)
	at org.apache.maven.cli.MavenCli.doMain(MavenCli.java:286)
	at org.apache.maven.cli.MavenCli.main(MavenCli.java:197)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:606)
	at org.codehaus.plexus.classworlds.launcher.Launcher.launchEnhanced(Launcher.java:289)
	at org.codehaus.plexus.classworlds.launcher.Launcher.launch(Launcher.java:229)
	at org.codehaus.plexus.classworlds.launcher.Launcher.mainWithExitCode(Launcher.java:415)
	at org.codehaus.plexus.classworlds.launcher.Launcher.main(Launcher.java:356)
Caused by: org.apache.maven.plugin.MojoFailureException: There are test failures.

Please refer to <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/ws/examples/java/target/failsafe-reports> for the individual test results.
Please refer to dump files (if any exist) [date]-jvmRun[N].dump, [date].dumpstream and [date]-jvmRun[N].dumpstream.
	at org.apache.maven.plugin.surefire.SurefireHelper.throwException(SurefireHelper.java:204)
	at org.apache.maven.plugin.surefire.SurefireHelper.reportExecution(SurefireHelper.java:98)
	at org.apache.maven.plugin.failsafe.VerifyMojo.execute(VerifyMojo.java:191)
	at org.apache.maven.plugin.DefaultBuildPluginManager.executeMojo(DefaultBuildPluginManager.java:134)
	at org.apache.maven.lifecycle.internal.MojoExecutor.execute(MojoExecutor.java:208)
	... 20 more
2017-05-22\T\20:56:48.643 [ERROR] 
2017-05-22\T\20:56:48.643 [ERROR] Re-run Maven using the -X switch to enable full debug logging.
2017-05-22\T\20:56:48.643 [ERROR] 
2017-05-22\T\20:56:48.643 [ERROR] For more information about the errors and possible solutions, please read the following articles:
2017-05-22\T\20:56:48.643 [ERROR] [Help 1] http://cwiki.apache.org/confluence/display/MAVEN/MojoFailureException
2017-05-22\T\20:56:48.643 [ERROR] 
2017-05-22\T\20:56:48.643 [ERROR] After correcting the problems, you can resume the build with the command
2017-05-22\T\20:56:48.643 [ERROR]   mvn <goals> -rf :beam-examples-java
Build step 'Invoke top-level Maven targets' marked build as failure
Not sending mail to unregistered user kirpichov@google.com
Not sending mail to unregistered user ccy@google.com
Not sending mail to unregistered user vikasrk@google.com
Not sending mail to unregistered user github@nakomis.com
Not sending mail to unregistered user jasonkuster@google.com
Not sending mail to unregistered user aljoscha.krettek@gmail.com
Not sending mail to unregistered user sourabhbajaj@google.com
Not sending mail to unregistered user mingmxu@ebay.com
Not sending mail to unregistered user klk@google.com
Not sending mail to unregistered user borisa.zivkovic@huawei.com

Jenkins build is back to normal : beam_PostCommit_Java_JDK_Versions_Test » JDK 1.7 (latest),beam #18

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_JDK_Versions_Test/jdk=JDK%201.7%20(latest),label=beam/18/display/redirect?page=changes>