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/22 13:13:34 UTC

Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Samza #1707

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

Changes:

[relax] Update JUnit

------------------------------------------
[...truncated 19.56 MB...]
    	at org.gradle.api.internal.tasks.testing.junit.JUnitTestClassExecutor.execute(JUnitTestClassExecutor.java:38)
    	at org.gradle.api.internal.tasks.testing.junit.AbstractJUnitTestClassProcessor.processTestClass(AbstractJUnitTestClassProcessor.java:66)
    	at org.gradle.api.internal.tasks.testing.SuiteTestClassProcessor.processTestClass(SuiteTestClassProcessor.java:51)
    	at sun.reflect.GeneratedMethodAccessor24.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.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 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got system producers: Set()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got serdes from factories: Set(byteSerde)
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got serdes from serialized instances: Set(NoOpSerde-2ee0eb8a-8ab8-4479-a718-7aba8ea604d2, NoOpSerde-0d07552a-5e00-4afc-9c91-5726162f0b2c)
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got change log system streams: Map()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got intermediate streams: List()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Setting up JVM metrics.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Setting up message chooser.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Building default chooser with: useBatching=false, useBootstrapping=false, usePriority=false
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Setting up metrics reporters.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got metrics reporters: Set()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got security manager: null
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got checkpoint manager: null
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got checkpointListeners : Map()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=0-Create_Values_Read_CreateSource__out__PCollection_, stream=0-Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: No default offset for SystemStream [system=11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, stream=11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_] defined. Using upcoming.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got offset manager: org.apache.samza.checkpoint.OffsetManager@6fdb5d9a
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got storage engines: Set(beamStore)
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got single thread mode: false
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got thread pool size: 0
    Dec 22, 2018 1:12:46 PM org.apache.samza.task.TaskFactoryUtil finalizeTaskFactory
    INFO: Converting StreamTask to AsyncStreamTaskAdapter when running StreamTask with multiple threads
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got store consumers: Map()
    Dec 22, 2018 1:12:46 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 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got base directory for non logged data stores: /tmp/beam-samza-test
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got base directory for logged data stores: /tmp/beam-samza-test
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got task stores: Map(beamStore -> org.apache.samza.storage.kv.KeyValueStorageEngine@75413913)
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got table manager
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Retrieved SystemStreamPartitions Set(SystemStreamPartition [0-Create_Values_Read_CreateSource__out__PCollection_, 0-Create_Values_Read_CreateSource__out__PCollection_, 0], SystemStreamPartition [11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0]) for Partition 0
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got window milliseconds: -1.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got commit milliseconds: -1.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got taskMaxConcurrency: 1.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got asyncCommitEnabled: false.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got callbackTimeout: -1.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Got maxIdleMs: 10.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.RunLoopFactory createRunLoop
    INFO: Run loop in asynchronous mode.
    Dec 22, 2018 1:12:46 PM org.apache.samza.container.disk.NoThrottlingDiskQuotaPolicy <init>
    INFO: Using a no throttling disk quota policy
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Disk quotas disabled because polling interval is not set (container.disk.poll.interval.ms)
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Samza container setup complete.
    Dec 22, 2018 1:12:46 PM org.apache.samza.processor.StreamProcessor$1 onNewJobModel
    INFO: Starting the container: org.apache.samza.container.SamzaContainer@4c24d2c4 for the stream processor: 1.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting container.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: According to Util.getLocalHost.getHostName we are apache-beam-jenkins-slave-group-znl1
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Not overriding system property com.sun.management.jmxremote.authenticate as already has value false
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Not overriding system property com.sun.management.jmxremote.ssl as already has value false
    Dec 22, 2018 1:12:46 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-znl1
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class startupLog
    INFO: Started JmxServer registry port=35229 server port=43103 url=service:jmx:rmi://localhost:43103/jndi/rmi://localhost:35229/jmxrmi
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class startupLog
    INFO: Started JmxServer registry port=35229 server port=43103 url=service:jmx:rmi://localhost:43103/jndi/rmi://localhost:35229/jmxrmi
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class startupLog
    INFO: If you are tunneling, you might want to try JmxServer registry port=35229 server port=43103 url=service:jmx:rmi://apache-beam-jenkins-slave-group-znl1:43103/jndi/rmi://apache-beam-jenkins-slave-group-znl1:35229/jmxrmi
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class startupLog
    INFO: If you are tunneling, you might want to try JmxServer registry port=35229 server port=43103 url=service:jmx:rmi://apache-beam-jenkins-slave-group-znl1:43103/jndi/rmi://apache-beam-jenkins-slave-group-znl1:35229/jmxrmi

org.apache.beam.sdk.transforms.KeysTest > testKeys STANDARD_OUT
    JMX Server: JmxServer registry port=35229 server port=43103 url=service:jmx:rmi://apache-beam-jenkins-slave-group-znl1:43103/jndi/rmi://apache-beam-jenkins-slave-group-znl1:35229/jmxrmi

org.apache.beam.sdk.transforms.KeysTest > testKeys STANDARD_ERROR
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with metrics.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting JVM metrics.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting metrics reporters.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting admin multiplexer.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with offsets.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting offset manager.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class warn
    WARNING: Requested offset type UPCOMING in SystemStreamPartition [0-Create_Values_Read_CreateSource__out__PCollection_, 0-Create_Values_Read_CreateSource__out__PCollection_, 0], but the stream is empty. Defaulting to the upcoming offset.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Successfully loaded last processed offsets: {}
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Successfully loaded starting offsets: Map(Partition 0 -> Map(SystemStreamPartition [11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_, 0] -> null, SystemStreamPartition [0-Create_Values_Read_CreateSource__out__PCollection_, 0-Create_Values_Read_CreateSource__out__PCollection_, 0] -> null))
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting stores in task instance Partition 0
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got non logged storage partition directory as /tmp/beam-samza-test/beamStore/Partition_0
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got logged storage partition directory as /tmp/beam-samza-test/beamStore/Partition_0
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Deleting logged storage partition directory /tmp/beam-samza-test/beamStore/Partition_0.
    Dec 22, 2018 1:12:46 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 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Validating change log streams: Map()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Got change log stream metadata: Map()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Assigning oldest change log offsets for taskName Partition 0: Map()
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting table manager in task instance Partition 0
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting host statistics monitor
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with producers.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting producer multiplexer.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Initializing stream tasks.
    Dec 22, 2018 1:12:46 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 0-Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 22, 2018 1:12:46 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 0-Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 22, 2018 1:12:46 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the key serde for stream 11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Keys will not be (de)serialized
    Dec 22, 2018 1:12:46 PM org.apache.samza.operators.StreamGraphImpl getKVSerdes
    INFO: Using NoOpSerde as the value serde for stream 11-PAssert_97_GroupGlobally_Create_Values_Read_CreateSource__out__PCollection_. Values will not be (de)serialized
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Registering task instances with consumers.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Starting consumer multiplexer.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class error
    SEVERE: Caught exception/error while initializing container.
    java.lang.OutOfMemoryError: unable to create new native thread
    	at java.lang.Thread.start0(Native Method)
    	at java.lang.Thread.start(Thread.java:717)
    	at org.apache.beam.runners.samza.adapter.BoundedSourceSystem$Consumer.start(BoundedSourceSystem.java:190)
    	at org.apache.samza.system.SystemConsumers$$anonfun$start$5.apply(SystemConsumers.scala:168)
    	at org.apache.samza.system.SystemConsumers$$anonfun$start$5.apply(SystemConsumers.scala:168)
    	at scala.collection.Iterator$class.foreach(Iterator.scala:891)
    	at scala.collection.AbstractIterator.foreach(Iterator.scala:1334)
    	at scala.collection.MapLike$DefaultValuesIterable.foreach(MapLike.scala:206)
    	at org.apache.samza.system.SystemConsumers.start(SystemConsumers.scala:168)
    	at org.apache.samza.container.SamzaContainer.startConsumers(SamzaContainer.scala:962)
    	at org.apache.samza.container.SamzaContainer.run(SamzaContainer.scala:734)
    	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
    	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
    	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
    	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
    	at java.lang.Thread.run(Thread.java:748)

    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down consumer multiplexer.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down task instance stream tasks.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down timer executor
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down task instance table manager.
    Dec 22, 2018 1:12:46 PM org.apache.samza.util.Logging$class info
    INFO: Shutting down task instance stores.
terminate called after throwing an instance of 'std::system_error'
  what():  No space left on device

org.apache.beam.sdk.transforms.KeysTest > testKeys SKIPPED

> Task :beam-runners-samza:validatesRunner FAILED
:beam-runners-samza:validatesRunner (Thread[Task worker for ':' Thread 9,5,main]) completed. Took 32.467 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 134
  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 4s
47 actionable tasks: 44 executed, 3 from cache

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

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 #1708

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


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