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 2018/12/18 18:54:04 UTC

Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Samza #1660

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

Changes:

[xinyuliu.us] [BEAM-6252] SamzaRunner: Add a registrar to allow customized DoFnInvoker

[xinyuliu.us] Allow Samza DoFnInvoker to generate configs and pass in TaskContext

[xinyuliu.us] [BEAM-6253] SamzaRunner: Add a few customized transforms for runner use

------------------------------------------
[...truncated 45.04 MB...]
    	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
    	at java.lang.reflect.Method.invoke(Method.java:498)
    	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:35)
    	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:24)
    	at org.gradle.internal.dispatch.ContextClassLoaderDispatch.dispatch(ContextClassLoaderDispatch.java:32)
    	at org.gradle.internal.dispatch.ProxyDispatchAdapter$DispatchingInvocationHandler.invoke(ProxyDispatchAdapter.java:93)
    	at com.sun.proxy.$Proxy2.processTestClass(Unknown Source)
    	at org.gradle.api.internal.tasks.testing.worker.TestWorker.processTestClass(TestWorker.java:117)
    	at sun.reflect.GeneratedMethodAccessor23.invoke(Unknown Source)
    	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
    	at java.lang.reflect.Method.invoke(Method.java:498)
    	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:35)
    	at org.gradle.internal.dispatch.ReflectionDispatch.dispatch(ReflectionDispatch.java:24)
    	at org.gradle.internal.remote.internal.hub.MessageHubBackedObjectConnection$DispatchWrapper.dispatch(MessageHubBackedObjectConnection.java:155)
    	at org.gradle.internal.remote.internal.hub.MessageHubBackedObjectConnection$DispatchWrapper.dispatch(MessageHubBackedObjectConnection.java:137)
    	at org.gradle.internal.remote.internal.hub.MessageHub$Handler.run(MessageHub.java:404)
    	at org.gradle.internal.concurrent.ExecutorPolicy$CatchAndRecordFailures.onExecute(ExecutorPolicy.java:63)
    	at org.gradle.internal.concurrent.ManagedExecutorImpl$1.run(ManagedExecutorImpl.java:46)
    	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
    	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
    	at org.gradle.internal.concurrent.ThreadFactoryImpl$ManagedThreadRunnable.run(ThreadFactoryImpl.java:55)
    	at java.lang.Thread.run(Thread.java:748)

    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got system producers: Set()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got serdes from factories: Set(byteSerde)
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got serdes from serialized instances: Set(NoOpSerde-81964a27-1e91-4089-b3c3-97d51a629235, NoOpSerde-ae44fd82-5aaf-4157-9ff8-fcf3827d8e48)
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got change log system streams: Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got intermediate streams: List()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Setting up JVM metrics.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Setting up message chooser.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Building default chooser with: useBatching=false, useBootstrapping=false, usePriority=false
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Setting up metrics reporters.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got metrics reporters: Set()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got security manager: null
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got checkpoint manager: null
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got checkpointListeners : Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=0-main_Create_Values_Read_CreateSource__out__PCollection_, stream=0-main_Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=3-side_Create_Values_Read_CreateSource__out__PCollection_, stream=3-side_Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, stream=42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, stream=62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got offset manager: org.apache.samza.checkpoint.OffsetManager@3560bb
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got storage engines: Set(beamStore)
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got single thread mode: false
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got thread pool size: 0
    Dec 18, 2018 6:53:13 PM org.apache.samza.task.TaskFactoryUtil finalizeTaskFactory
    INFO: Converting StreamTask to AsyncStreamTaskAdapter when running StreamTask with multiple threads
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got store consumers: Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got default storage engine base directory: <https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Samza/ws/src/runners/samza/state>
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got base directory for non logged data stores: /tmp/beam-samza-test
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got base directory for logged data stores: /tmp/beam-samza-test
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got task stores: Map(beamStore -> org.apache.samza.storage.kv.KeyValueStorageEngine@4bf0ae6b)
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got table manager
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Retrieved SystemStreamPartitions Set(SystemStreamPartition [0-main_Create_Values_Read_CreateSource__out__PCollection_, 0-main_Create_Values_Read_CreateSource__out__PCollection_, 0], SystemStreamPartition [42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0], SystemStreamPartition [62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0], SystemStreamPartition [3-side_Create_Values_Read_CreateSource__out__PCollection_, 3-side_Create_Values_Read_CreateSource__out__PCollection_, 0]) for Partition 0
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got window milliseconds: -1.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got commit milliseconds: -1.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got taskMaxConcurrency: 1.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got asyncCommitEnabled: false.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got callbackTimeout: -1.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got maxIdleMs: 10.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Run loop in asynchronous mode.
    Dec 18, 2018 6:53:13 PM org.apache.samza.container.disk.NoThrottlingDiskQuotaPolicy <init>
    INFO: Using a no throttling disk quota policy
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Disk quotas disabled because polling interval is not set (container.disk.poll.interval.ms)
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Samza container setup complete.
    Dec 18, 2018 6:53:13 PM org.apache.samza.processor.StreamProcessor$1 onNewJobModel
    INFO: Starting the container: org.apache.samza.container.SamzaContainer@226644c0 for the stream processor: 1.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting container.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: According to Util.getLocalHost.getHostName we are apache-beam-jenkins-slave-group-lbw6
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Not overriding system property com.sun.management.jmxremote.authenticate as already has value false
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Not overriding system property com.sun.management.jmxremote.ssl as already has value false
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Not overriding system property java.rmi.server.hostname as already has value apache-beam-jenkins-slave-group-lbw6
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class startupLog
    INFO: Started JmxServer registry port=35801 server port=42643 url=service:jmx:rmi://localhost:42643/jndi/rmi://localhost:35801/jmxrmi
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class startupLog
    INFO: Started JmxServer registry port=35801 server port=42643 url=service:jmx:rmi://localhost:42643/jndi/rmi://localhost:35801/jmxrmi
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class startupLog
    INFO: If you are tunneling, you might want to try JmxServer registry port=35801 server port=42643 url=service:jmx:rmi://apache-beam-jenkins-slave-group-lbw6:42643/jndi/rmi://apache-beam-jenkins-slave-group-lbw6:35801/jmxrmi
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class startupLog
    INFO: If you are tunneling, you might want to try JmxServer registry port=35801 server port=42643 url=service:jmx:rmi://apache-beam-jenkins-slave-group-lbw6:42643/jndi/rmi://apache-beam-jenkins-slave-group-lbw6:35801/jmxrmi

org.apache.beam.sdk.transforms.SplittableDoFnTest > testWindowedSideInputWithCheckpointsBounded STANDARD_OUT
    JMX Server: JmxServer registry port=35801 server port=42643 url=service:jmx:rmi://apache-beam-jenkins-slave-group-lbw6:42643/jndi/rmi://apache-beam-jenkins-slave-group-lbw6:35801/jmxrmi

org.apache.beam.sdk.transforms.SplittableDoFnTest > testWindowedSideInputWithCheckpointsBounded STANDARD_ERROR
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with metrics.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting JVM metrics.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting metrics reporters.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting admin multiplexer.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with offsets.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting offset manager.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [0-main_Create_Values_Read_CreateSource__out__PCollection_, 0-main_Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [3-side_Create_Values_Read_CreateSource__out__PCollection_, 3-side_Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Successfully loaded last processed offsets: {}
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Successfully loaded starting offsets: Map(Partition 0 -> Map(SystemStreamPartition [0-main_Create_Values_Read_CreateSource__out__PCollection_, 0-main_Create_Values_Read_CreateSource__out__PCollection_, 0] -> null, SystemStreamPartition [42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0] -> null, SystemStreamPartition [3-side_Create_Values_Read_CreateSource__out__PCollection_, 3-side_Create_Values_Read_CreateSource__out__PCollection_, 0] -> null, SystemStreamPartition [62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0] -> null))
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting stores in task instance Partition 0
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got non logged storage partition directory as /tmp/beam-samza-test/beamStore/Partition_0
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got logged storage partition directory as /tmp/beam-samza-test/beamStore/Partition_0
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Deleting logged storage partition directory /tmp/beam-samza-test/beamStore/Partition_0.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Using non logged storage partition directory: /tmp/beam-samza-test/beamStore/Partition_0 for store: beamStore.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Validating change log streams: Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Got change log stream metadata: Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Assigning oldest change log offsets for taskName Partition 0: Map()
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting table manager in task instance Partition 0
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting host statistics monitor
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with producers.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting producer multiplexer.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Initializing stream tasks.
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 0-main_Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 0-main_Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 3-side_Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 3-side_Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with consumers.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Starting consumer multiplexer.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: Entering run loop.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: SystemStreamPartition [0-main_Create_Values_Read_CreateSource__out__PCollection_, 0-main_Create_Values_Read_CreateSource__out__PCollection_, 0] is catched up.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class warn
    WARNING: Using arrays as keys results in unpredictable behavior since cache is implemented with a map. Consider using ByteBuffer, or a different key type, or turn off the cache altogether.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: SystemStreamPartition [42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0] is catched up.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: SystemStreamPartition [62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0] is catched up.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: SystemStreamPartition [3-side_Create_Values_Read_CreateSource__out__PCollection_, 3-side_Create_Values_Read_CreateSource__out__PCollection_, 0] is catched up.
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: End of stream reached for partition: SystemStreamPartition [42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 42-PAssert_250_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0]
    Dec 18, 2018 6:53:13 PM org.apache.samza.util.Logging$class info
    INFO: End of stream reached for partition: SystemStreamPartition [62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 62-PAssert_251_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0]
#
Java HotSpot(TM) 64-Bit Server VM warning: INFO: os::commit_memory(0x000000069e580000, 611319808, 0) failed; error='Cannot allocate memory' (errno=12)
# There is insufficient memory for the Java Runtime Environment to continue.
# Native memory allocation (mmap) failed to map 611319808 bytes for committing reserved memory.
# An error report file with more information is saved as:
# <https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Samza/ws/src/runners/samza/hs_err_pid9672.log>

org.apache.beam.sdk.transforms.SplittableDoFnTest > testWindowedSideInputWithCheckpointsBounded SKIPPED

> Task :beam-runners-samza:validatesRunner FAILED
:beam-runners-samza:validatesRunner (Thread[Task worker for ':' Thread 3,5,main]) completed. Took 1 mins 18.821 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-samza:validatesRunner'.
> Process 'Gradle Test Executor 1' finished with non-zero exit value 1
  This problem might be caused by incorrect test process configuration.
  Please refer to the test execution section in the user guide at https://docs.gradle.org/4.10.2/userguide/java_plugin.html#sec:test_execution

* Try:
Run with --stacktrace option to get the stack trace. Run with --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 5.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/4.10.2/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3m 51s
46 actionable tasks: 42 executed, 4 from cache

Publishing build scan...
https://gradle.com/s/43livg5axme6y

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_PostCommit_Java_ValidatesRunner_Samza #1661

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


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