See
<https://builds.apache.org/job/beam_PostCommit_Java_RunnableOnService_Gearpump/156/changes>
Changes:
[ansela] [BEAM-1000, BEAM-1050] Fixed PipelineResult.State Failed for streaming,
[ansela] Redistributed some responsibilities in order to remove
[klk] Update Dataflow worker to beam-master-20161205
[klk] Moved KeyedWorkItem and related classes to runners-core
[klk] Deprecate TimerCallback and InMemoryTimerInternals methods using it.
[klk] Add test for InMemoryTimerInternals synchronized processing time timers.
[jbonofre] [BEAM-961] Add starting number to CountingInput
[klk] BEAM-651: Rename setTypeDescriptorInternal to setTypeDescriptor
[davor] [BEAM-293] StreamingOptions doesn't extend GcpOptions
[tgroh] Add DirectGraphs to DirectRunner Tests
[tgroh] Remove getProducingTransformInternal from DirectGraphVisitorTest
[davor] Update subnetwork documentation
[davor] Improve BigQuery load error message
[klk] Improve ReduceFnRunner prefetching
[klk] Allow stateful DoFn in DataflowRunner
[davor] [BEAM-551] Add DisplayData handling of ValueProvider<String>
[davor] [BEAM-551] Add support for native PubSubIO
[davor] [BEAM-1099] Minor typos in KafkaIO
[bchambers] [Code Health] Remove redundant projectId from DataflowPipelineJob.
[bchambers] [BEAM-1047] Add DataflowClient wrapper on top of JSON library.
[bchambers] [BEAM-1047] Update dataflow runner code to use DataflowClient
wrapper.
[dhalperi] BigQueryIO.Read: support runtime options
[aljoscha.krettek] [FLINK-1102] Fix Aggregator Registration in Flink Batch
Runner
[ansela] [BEAM-1094] Set test scope for Kafka IO and junit
[jbonofre] [BEAM-329] Update Spark runner README.
[tgroh] Port most of DoFnRunner Javadoc to new DoFn
[klk] Port ParDoTest from OldDoFn to new DoFn
[tgroh] Only provide expanded Inputs and Outputs
[dhalperi] [BEAM-905] Add shading config to examples archetype and enable it for
[dhalperi] [BEAM-1108] DataflowRunner: remove deprecated TEARDOWN_POLICY control
[aljoscha.krettek] [BEAM-1095] Add support set config for reuse-object on flink
[aljoscha.krettek] [BEAM-1096] Flink streaming side output optimization using
SplitStream
[klk] Add DoFn.OnTimerContext
[klk] Add OnTimerContext parameter support to DoFnSignature
[klk] Access to OnTimerContext via DoFnInvokers.ArgumentProvider
[klk] Support OnTimerContext in ByteBuddyDoFnInvokerFactory
[klk] Move CopyOnAccessStateInternals to runners/direct
[lcwik] Remove misc occurrences of OldDoFn
[klk] Rename PTransform.apply to PTransform.expand
[klk] Add JUnit category UsesTimersInParDo
[klk] Disable tests for timers in ParDo for Apex runner
[klk] Disable tests for timers in ParDo for Flink runner
[klk] Disables tests for timers in ParDo for Spark runner
[klk] Disable tests for timers in ParDo for Dataflow runner
[klk] Disable tests for timers in ParDo for direct runner
[klk] Add basic test for timers in ParDoTest
[klk] Reject timers for ParDo in ApexRunner
[klk] Reject timers for ParDo in FlinkRunner
[klk] Reject timers for ParDo in SparkRunner
[klk] Reject timers for ParDo in DirectRunner
[klk] No longer reject timers in ParDo
[klk] [BEAM-1111] Reject timers for ParDo in SparkRunner streaming evaluators
[klk] Fix exclusion of UsesTimersInParDo for FlinkRunner streaming tests
[klk] [BEAM-978] Support bulk get file size in GcsUtil.
[tgroh] Fix a bug in SplittableDoFn Checkpointing
[lcwik] Add support for having an empty CountingInput/CountingSource
[lcwik] fixup! Fix CountingInput naming
[lcwik] fixup! Fix extraneous brace
[dhalperi] DataflowRunner: bump environment major version
[ansela] Remove misc uses of OldDoFn
[tgroh] Enable the DirectRunner by default in Examples Archetype
[davor] [BEAM-1093] Change Dataflow to Beam in StateInternals' Javadocs
[davor] Change Dataflow profiling option to saveProfilesToGcs
[tgroh] Copy Runner Profiles to Java8 Archetype POM
[klk] Fix LateDataDroppingDoFnRunner to not increment the counter on
[github] Update badge for new suite name.
[thw] BEAM-830 Support launch on YARN cluster.
[davor] [BEAM-551] Fix handling of TextIO.Sink
[ansela] [BEAM-921] spark-runner: register sources and coders to serialize with
[davor] [BEAM-551] Fix toString for FileBasedSource
[dhalperi] [BEAM-1120] Move some DataflowRunner configurations from code to
[dhalperi] [BEAM-551] Fix handling of default for VP
[dhalperi] Fix handling of null ValueProviders in DisplayData
[dhalperi] BigQueryIO.Write: support runtime schema and table
[klk] [BEAM-1133] Add maxNumRecords per micro-batch for Spark runner options.
[klk] [BEAM-1130] SparkRunner ResumeFromCheckpointStreamingTest Failing.
[bchambers] Enable and fix DirectRunnerTest case missing @Test
[tgroh] Migrate AppliedPTransform to use AutoValue
[tgroh] Stop expanding PValues in DirectRunner visitors
[klk] Add IntervalWindow coder to the standard registry
[klk] Factor out ShardedFile from FileChecksumMatcher
[klk] Revise WindowedWordCount for runner and execution mode portability
[tgroh] Add no-arg constructor for UnboundedReadFromBoundedSource
[tgroh] Add Tests for Kryo Serialization of URFBS
[davor] [BEAM-1142] Upgrade maven-invoker to address maven bug ARCHETYPE-488.
[davor] FileBasedSink: ignore exceptions when removing temp output files for
[davor] FileBasedSinkTest: fix tests in Windows OS by using
[ansela] [BEAM-757] Use DoFnRunner in the implementation of DoFn via
[ansela] [BEAM-807] Replace OldDoFn with DoFn.
[davor] [BEAM-927] Fix findbugs and re-enable Maven plugin in JmsIO
[davor] Fix JDom malformed comment in Apex runner.
[dhalperi] [BEAM-909] improve starter archetype
[klk] Revert 91cc606 "This closes #1586": Kryo + UBRFBS
[klk] Fix version of Kryo in examples/java jenkins-precommit profile
[davor] [maven-release-plugin] prepare branch release-0.4.0-incubating
[davor] [maven-release-plugin] prepare for next development iteration
[klk] Update Dataflow worker to beam-master-20161212
[klk] Move PerKeyCombineFnRunner to runners-core
[davor] Update Maven Archetype versions after cutting the release branch
[davor] Update version from 0.5.0-SNAPSHOT to 0.5.0-incubating-SNAPSHOT
[klk] Add Jenkins postcommit for RunnableOnService in Apex runner
[klk] [BEAM-1149] Explode windows when fn uses side inputs
[dhalperi] Some minor changes and fixes for sorter module
[klk] Re-exclude UsesStatefulParDo tests for Dataflow
[klk] Revert "Allow stateful DoFn in DataflowRunner"
[dhalperi] starter: fix typo in pom.xml
[lcwik] Allow empty string value for ValueProvider types.
[lcwik] Better comments and cleanup
[klk] SimpleDoFnRunner observes window if SideInputReader is nonempty
[tgroh] Implement GetDefaultOutputCoder in DirectGroupByKey
[tgroh] [BEAM-1033] Retry Bigquery Verifier when Query Fails
[klk] Fix NPE in StatefulParDoEvaluatorFactoryTest mocking
[dhalperi] [BEAM-1153] GcsUtil: use non-batch API for single file size requests.
[kirpichov] [BEAM-1154] Get side input from proper window in ReduceFn
[dhalperi] Fail to split in FileBasedSource if filePattern expands to empty.
[iemejia] [BEAM-932] Enable findbugs validation (and fix existing issues)
[klk] Fix mvn command args in Apex postcommit Jenkins job
[dhalperi] [BEAM-1022] Add testing coverage for BigQuery streaming writes
[kirpichov] Converts all easy OldDoFns to DoFn
[kirpichov] Remove ParDo.of(OldDoFn) from Apex runner
[kirpichov] Pushes uses of OldDoFn deeper inside Flink runner
[kirpichov] Removes OldDoFn from ParDo
[kirpichov] Removes code for wrapping DoFn as an OldDoFn
[kirpichov] Removes ArgumentProvider.windowingInternals
[kirpichov] Removes unused code from NoOpOldDoFn
[kirpichov] Moves DoFnAdapters to runners-core
[kirpichov] Renames ParDo.getNewFn to getFn
[bchambers] Don't incorrectly log error in MetricsEnvironment
[klk] Remove deprecated methods of InMemoryTimerInternals
[klk] Delete deprecated TimerCallback
[klk] Move InMemoryTimerInternals to runners-core
[ansela] [BEAM-362] Port runners to runners-core AggregatoryFactory
[dhalperi] [BEAM-450] Shade modules to separate paths
[dhalperi] [BEAM-1108] Remove outdated language about experimental autoscaling
[klk] Update Dataflow worker to beam-master-20161216
[klk] Move ActiveWindowSet and implementations to runners-core
[tgroh] Add PTransformOverrideFactory to the Core SDK
[bchambers] Make {Metric,Counter,Distribution}Cell public
[kirpichov] checkstyle: missed newline in DistributionCell
[kirpichov] Revert "Removes code for wrapping DoFn as an OldDoFn"
[kirpichov] Revert "Removes ArgumentProvider.windowingInternals"
[kirpichov] Revert "Moves DoFnAdapters to runners-core"
[kirpichov] Revert "Move InMemoryTimerInternals to runners-core"
[dhalperi] View.asMap: minor javadoc fixes
[klk] Make TimerSpec and StateSpec fields accessible
[klk] Add timer support to DoFnRunner(s)
[klk] Test that SimpleDoFnRunner wraps exceptions in startBundle and
[klk] Use empty SideInputReader, fixes NPE in SimpleDoFnRunnerTest
[klk] [BEAM-853] Force streaming execution on batch pipelines for testing.
[dhalperi] BigQueryIO: fix streaming write, typo in API
[joshualitt] Change counter name in TestDataflowRunner
[klk] [BEAM-85, BEAM-298] Make TestPipeline a JUnit Rule checking proper usage
[klk] Empty TestPipeline need not be run
[iemejia] Fix grammar error (repeated for)
[jbonofre] [BEAM-716] Use AutoValue in JmsIO
[jbonofre] [BEAM-716] Fix javadoc on with* methods [BEAM-959] Improve check
[iemejia] [BEAM-1178] Make naming of logger objects consistent
[aljoscha.krettek] [BEAM-1165] Fix unexpected file creation when checking
dependencies
[klk] Show timestamps on log lines in Jenkins
[klk] Fix seed job fetch spec
[bchambers] Add RunnableOnService test for Metrics
[klk] More escaping in Jenkins timestamp spec
[bchambers] Change counter name in TestDataflowRunner
[lcwik] [BEAM-59] initial interfaces and classes of Beam FileSystem.
[dhalperi] Disable automatic archiving of Maven builds
[owenzhang1990] [BEAM-79] Update to latest Gearpump API
[owenzhang1990] [BEAM-79] Upgrade to beam-0.5.0-incubating-SNAPSHOT
------------------------------------------
[...truncated 28583 lines...]
ApproximateUniqueTest.testApproximateUniqueWithSmallInput:70 » Runtime Failed
...
CombineFnsTest.testComposedCombine:126 » Runtime Failed to construct instance
...
CombineFnsTest.testComposedCombineNullValues:243 » Runtime Failed to
construct...
CombineFnsTest.testComposedCombineWithContext:181 » Runtime Failed to
construc...
CombineTest.testAccumulatingCombine:477->runTestAccumulatingCombine:236 »
Runtime
CombineTest.testAccumulatingCombineEmpty:483->runTestAccumulatingCombine:236
» Runtime
CombineTest.testBasicCombine:221->runTestBasicCombine:200 » Runtime Failed to
...
CombineTest.testBasicCombineEmpty:229->runTestBasicCombine:200 » Runtime
Faile...
CombineTest.testCombineGloballyAsSingletonView:635 » Runtime Failed to
constru...
CombineTest.testCombinePerKeyPrimitiveDisplayData:712 » Runtime Failed to
cons...
CombineTest.testCombinePerKeyWithHotKeyFanoutPrimitiveDisplayData:729 »
Runtime
CombineTest.testFixedWindowsCombine:256 » Runtime Failed to construct
instance...
CombineTest.testFixedWindowsCombineWithContext:282 » Runtime Failed to
constru...
CombineTest.testGlobalCombineWithDefaultsAndTriggers:368 » Runtime Failed to
c...
CombineTest.testHotKeyCombining:520 » Runtime Failed to construct instance
fro...
CombineTest.testHotKeyCombiningWithAccumulationMode:555 » Runtime Failed to
co...
CombineTest.testSessionsCombine:395 » Runtime Failed to construct instance
fro...
CombineTest.testSessionsCombineWithContext:420 » Runtime Failed to construct
i...
CombineTest.testSimpleCombine:171->runTestSimpleCombine:120 » Runtime Failed
t...
CombineTest.testSimpleCombineEmpty:193->runTestSimpleCombine:120 » Runtime
Fai...
CombineTest.testSimpleCombineWithContext:178->runTestSimpleCombineWithContext:141
» Runtime
CombineTest.testSimpleCombineWithContextEmpty:186->runTestSimpleCombineWithContext:141
» Runtime
CombineTest.testSlidingWindowsCombineWithContext:319 » Runtime Failed to
const...
CombineTest.testWindowedCombineEmpty:462 » Runtime Failed to construct
instanc...
CountTest.testCountGloballyBasic:88 » Runtime Failed to construct instance
fro...
CountTest.testCountGloballyEmpty:103 » Runtime Failed to construct instance
fr...
CountTest.testCountPerElementBasic:52 » Runtime Failed to construct instance
f...
CountTest.testCountPerElementEmpty:74 » Runtime Failed to construct instance
f...
CreateTest.testCreate:83 » Runtime Failed to construct instance from factory
m...
CreateTest.testCreateEmpty:96 » Runtime Failed to construct instance from
fact...
CreateTest.testCreateTimestamped:238 » Runtime Failed to construct instance
fr...
CreateTest.testCreateTimestampedEmpty:257 » Runtime Failed to construct
instan...
CreateTest.testCreateWithKVVoidType:307 » Runtime Failed to construct
instance...
CreateTest.testCreateWithNullsAndValues:140 » Runtime Failed to construct
inst...
CreateTest.testCreateWithUnserializableElements:219 » Runtime Failed to
constr...
CreateTest.testCreateWithVoidType:298 » Runtime Failed to construct instance
f...
DistinctTest.testDistinct:56 » Runtime Failed to construct instance from
facto...
DistinctTest.testDistinctEmpty:75 » Runtime Failed to construct instance from
...
DistinctTest.testDistinctWithRepresentativeValue:118 » Runtime Failed to
const...
FilterTest.testFilterByPredicate:89 » Runtime Failed to construct instance
fro...
FilterTest.testFilterGreaterThan:115 » Runtime Failed to construct instance
fr...
FilterTest.testFilterGreaterThanEq:141 » Runtime Failed to construct instance
...
FilterTest.testFilterLessThan:102 » Runtime Failed to construct instance from
...
FilterTest.testFilterLessThanEq:128 » Runtime Failed to construct instance
fro...
FilterTest.testIdentityFilterByPredicate:63 » Runtime Failed to construct
inst...
FilterTest.testNoFilterByPredicate:76 » Runtime Failed to construct instance
f...
FlattenTest.testEmptyFlattenAsSideInput:157 » Runtime Failed to construct
inst...
FlattenTest.testFlattenInputMultipleCopies:123 » Runtime Failed to construct
i...
FlattenTest.testFlattenIterables:214 » Runtime Failed to construct instance
fr...
FlattenTest.testFlattenIterablesCollections:265 » Runtime Failed to construct
...
FlattenTest.testFlattenIterablesEmpty:283 » Runtime Failed to construct
instan...
FlattenTest.testFlattenIterablesLists:232 » Runtime Failed to construct
instan...
FlattenTest.testFlattenIterablesSets:247 » Runtime Failed to construct
instanc...
FlattenTest.testFlattenPCollectionList:77 » Runtime Failed to construct
instan...
FlattenTest.testFlattenPCollectionListEmpty:110 » Runtime Failed to construct
...
FlattenTest.testFlattenPCollectionListEmptyThenParDo:183 » Runtime Failed to
c...
FlattenTest.testFlattenPCollectionListThenParDo:93 » Runtime Failed to
constru...
GroupByKeyTest.testGroupByKey:98 » Runtime Failed to construct instance from
f...
GroupByKeyTest.testGroupByKeyAndWindows:140 » Runtime Failed to construct
inst...
GroupByKeyTest.testGroupByKeyEmpty:177 » Runtime Failed to construct instance
...
GroupByKeyTest.testGroupByKeyWithBadEqualsHashCode:411 » Runtime Failed to
con...
GroupByKeyTest.testOutputTimeFnEarliest:334 » Runtime Failed to construct
inst...
GroupByKeyTest.testOutputTimeFnLatest:356 » Runtime Failed to construct
instan...
KeysTest.testKeys:56 » Runtime Failed to construct instance from factory
metho...
KeysTest.testKeysEmpty:72 » Runtime Failed to construct instance from factory
...
KvSwapTest.testKvSwap:56 » Runtime Failed to construct instance from factory
m...
KvSwapTest.testKvSwapEmpty:78 » Runtime Failed to construct instance from
fact...
MapElementsTest.testPrimitiveDisplayData:265 » Runtime Failed to construct
ins...
ParDoLifecycleTest.testFnCallSequence:130 » Runtime Failed to construct
instan...
ParDoLifecycleTest.testFnCallSequenceMulti:142 » Runtime Failed to construct
i...
ParDoLifecycleTest.testOldFnCallSequence:49 » Runtime Failed to construct
inst...
ParDoLifecycleTest.testOldFnCallSequenceMulti:61 » Runtime Failed to
construct...
ParDoTest.testBagState:1565 » Runtime Failed to construct instance from
factor...
ParDoTest.testBagStateSideInput:1579 » Runtime Failed to construct instance
fr...
ParDoTest.testMultiOutputParDoWithSideInputs:635 » Runtime Failed to
construct...
ParDoTest.testMultiOutputParDoWithSideInputsIsCumulative:673 » Runtime Failed
...
ParDoTest.testParDo:305 » Runtime Failed to construct instance from factory
me...
ParDoTest.testParDo2:322 » Runtime Failed to construct instance from factory
m...
ParDoTest.testParDoEmpty:339 » Runtime Failed to construct instance from
facto...
ParDoTest.testParDoEmptyOutputs:357 » Runtime Failed to construct instance
fro...
ParDoTest.testParDoEmptyWithSideOutputs:416 » Runtime Failed to construct
inst...
ParDoTest.testParDoInCustomTransform:883 » Runtime Failed to construct
instanc...
ParDoTest.testParDoWithEmptySideOutputs:457 » Runtime Failed to construct
inst...
ParDoTest.testParDoWithOnlySideOutputs:485 » Runtime Failed to construct
insta...
ParDoTest.testParDoWithSideInputs:569 » Runtime Failed to construct instance
f...
ParDoTest.testParDoWithSideInputsIsCumulative:601 » Runtime Failed to
construc...
ParDoTest.testParDoWithSideOutputs:373 » Runtime Failed to construct instance
...
ParDoTest.testSideInputsWithMultipleWindows:749 » Runtime Failed to construct
...
ParDoTest.testSimpleEventTimeTimer:1661 » Runtime Failed to construct
instance...
ParDoTest.testValueStateSideOutput:1517 » Runtime Failed to construct
instance...
ParDoTest.testValueStateSimple:1480 » Runtime Failed to construct instance
fro...
ParDoTest.testWindowingInStartAndFinishBundle:1356 » Runtime Failed to
constru...
PartitionTest.testEvenOddPartition:69 » Runtime Failed to construct instance
f...
SampleTest.testPickAny:238->runPickAnyTest:220 » Runtime Failed to construct
i...
SampleTest.testPickAnyWhenEmpty:255->runPickAnyTest:220 » Runtime Failed to
co...
SampleTest.testSample:108 » Runtime Failed to construct instance from factory
...
SampleTest.testSampleEmpty:123 » Runtime Failed to construct instance from
fac...
SampleTest.testSampleInsufficientElements:153 » Runtime Failed to construct
in...
SampleTest.testSampleMultiplicity:177 » Runtime Failed to construct instance
f...
SampleTest.testSampleZero:138 » Runtime Failed to construct instance from
fact...
SplittableDoFnTest.testLateData:347 » Runtime Failed to construct instance
fro...
SplittableDoFnTest.testLifecycleMethods:442 » Runtime Failed to construct
inst...
SplittableDoFnTest.testOutputAfterCheckpoint:280 » Runtime Failed to
construct...
SplittableDoFnTest.testPairWithIndexBasic:157 » Runtime Failed to construct
in...
SplittableDoFnTest.testPairWithIndexWindowedTimestamped:183 » Runtime Failed
t...
SplittableDoFnTest.testSideInputsAndOutputs:320 » Runtime Failed to construct
...
ValuesTest.testValues:58 » Runtime Failed to construct instance from factory
m...
ValuesTest.testValuesEmpty:75 » Runtime Failed to construct instance from
fact...
ViewTest.testCombinedMapSideInput:1148 » Runtime Failed to construct instance
...
ViewTest.testEmptyIterableSideInput:404 » Runtime Failed to construct
instance...
ViewTest.testEmptyListSideInput:265 » Runtime Failed to construct instance
fro...
ViewTest.testEmptyMapSideInput:1007 » Runtime Failed to construct instance
fro...
ViewTest.testEmptyMapSideInputWithNonDeterministicKeyCoder:1036 » Runtime
Fail...
ViewTest.testEmptyMultimapSideInput:694 » Runtime Failed to construct
instance...
ViewTest.testEmptyMultimapSideInputWithNonDeterministicKeyCoder:723 » Runtime
...
ViewTest.testIterableSideInput:338 » Runtime Failed to construct instance
from...
ViewTest.testIterableSideInputIsImmutable:430 » Runtime Failed to construct
in...
ViewTest.testListSideInput:197 » Runtime Failed to construct instance from
fac...
ViewTest.testListSideInputIsImmutable:292 » Runtime Failed to construct
instan...
ViewTest.testMapAsEntrySetSideInput:828 » Runtime Failed to construct
instance...
ViewTest.testMapSideInput:801 » Runtime Failed to construct instance from
fact...
ViewTest.testMapSideInputIsImmutable:1101 » Runtime Failed to construct
instan...
ViewTest.testMapSideInputWithNonDeterministicKeyCoder:858 » Runtime Failed to
...
ViewTest.testMultimapAsEntrySetSideInput:490 » Runtime Failed to construct
ins...
ViewTest.testMultimapSideInput:462 » Runtime Failed to construct instance
from...
ViewTest.testMultimapSideInputIsImmutable:753 » Runtime Failed to construct
in...
ViewTest.testMultimapSideInputWithNonDeterministicKeyCoder:542 » Runtime
Faile...
ViewTest.testSideInputWithNestedIterables:1302 » Runtime Failed to construct
i...
ViewTest.testSideInputWithNullDefault:1272 » Runtime Failed to construct
insta...
ViewTest.testSingletonSideInput:92 » Runtime Failed to construct instance
from...
ViewTest.testWindowedIterableSideInput:364 » Runtime Failed to construct
insta...
ViewTest.testWindowedListSideInput:224 » Runtime Failed to construct instance
...
ViewTest.testWindowedMapAsEntrySetSideInput:925 » Runtime Failed to construct
...
ViewTest.testWindowedMapSideInput:887 » Runtime Failed to construct instance
f...
ViewTest.testWindowedMapSideInputWithNonDeterministicKeyCoder:967 » Runtime
Fa...
ViewTest.testWindowedMultimapAsEntrySetSideInput:611 » Runtime Failed to
const...
ViewTest.testWindowedMultimapSideInput:572 » Runtime Failed to construct
insta...
ViewTest.testWindowedMultimapSideInputWithNonDeterministicKeyCoder:654 »
Runtime
ViewTest.testWindowedSideInputFixedToFixed:1175 » Runtime Failed to construct
...
ViewTest.testWindowedSideInputFixedToFixedWithDefault:1241 » Runtime Failed
to...
ViewTest.testWindowedSideInputFixedToGlobal:1208 » Runtime Failed to
construct...
ViewTest.testWindowedSingletonSideInput:115 » Runtime Failed to construct
inst...
WithTimestampsTest.withTimestampsBackwardsInTimeAndWithAllowedTimestampSkewShouldSucceed:123
» Runtime
WithTimestampsTest.withTimestampsShouldApplyTimestamps:50 » Runtime Failed to
...
WithTimestampsTest.withTimestampsWithNullFnShouldThrowOnConstruction:200 »
Runtime
CoGroupByKeyTest.testCoGroupByKey:267 » Runtime Failed to construct instance
f...
CoGroupByKeyTest.testCoGroupByKeyGetOnly:127 » Runtime Failed to construct
ins...
CoGroupByKeyTest.testCoGroupByKeyHandleResults:459 » Runtime Failed to
constru...
CoGroupByKeyTest.testCoGroupByKeyWithWindowing:489 » Runtime Failed to
constru...
WindowTest.testOutputTimeFnDefault:188 » Runtime Failed to construct instance
...
WindowTest.testOutputTimeFnEndOfWindow:222 » Runtime Failed to construct
insta...
WindowingTest.testMergingWindowing:143 » Runtime Failed to construct instance
...
WindowingTest.testNonPartitioningWindowing:117 » Runtime Failed to construct
i...
WindowingTest.testPartitioningWindowing:91 » Runtime Failed to construct
insta...
WindowingTest.testWindowPreservation:165 » Runtime Failed to construct
instanc...
ReshuffleTest.testJustReshuffle:71 » Runtime Failed to construct instance
from...
ReshuffleTest.testReshuffleAfterFixedWindows:164 » Runtime Failed to
construct...
ReshuffleTest.testReshuffleAfterFixedWindowsAndGroupByKey:116 » Runtime
Failed...
ReshuffleTest.testReshuffleAfterSessionsAndGroupByKey:92 » Runtime Failed to
c...
ReshuffleTest.testReshuffleAfterSlidingWindows:188 » Runtime Failed to
constru...
ReshuffleTest.testReshuffleAfterSlidingWindowsAndGroupByKey:140 » Runtime
Fail...
PCollectionTupleTest.testComposePCollectionTuple:64 » Runtime Failed to
constr...
Tests run: 203, Failures: 0, Errors: 200, Skipped: 3
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
[JENKINS] Archiving disabled
2016-12-21T20:33:34.176 [INFO]
------------------------------------------------------------------------
2016-12-21T20:33:34.176 [INFO] Reactor Summary:
2016-12-21T20:33:34.176 [INFO]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: Parent
.............................. SUCCESS [ 19.023 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: SDKs :: Java :: Build Tools
......... SUCCESS [ 5.555 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: SDKs
................................ SUCCESS [ 1.141 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: SDKs :: Java
........................ SUCCESS [ 2.186 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: SDKs :: Java :: Core
................ SUCCESS [01:53 min]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: Runners
............................. SUCCESS [ 0.716 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: Runners :: Core Java
................ SUCCESS [ 15.529 s]
2016-12-21T20:33:34.177 [INFO] Apache Beam :: Runners :: Gearpump
................. FAILURE [ 24.796 s]
2016-12-21T20:33:34.177 [INFO]
------------------------------------------------------------------------
2016-12-21T20:33:34.177 [INFO] BUILD FAILURE
2016-12-21T20:33:34.177 [INFO]
------------------------------------------------------------------------
2016-12-21T20:33:34.177 [INFO] Total time: 03:31 min
2016-12-21T20:33:34.177 [INFO] Finished at: 2016-12-21T20:33:34+00:00
2016-12-21T20:33:35.151 [INFO] Final Memory: 168M/1528M
2016-12-21T20:33:35.151 [INFO]
------------------------------------------------------------------------
Waiting for Jenkins to finish collecting data
2016-12-21T20:33:38.759 [ERROR] Failed to execute goal
org.apache.maven.plugins:maven-surefire-plugin:2.19.1:test
(runnable-on-service-tests) on project beam-runners-gearpump: There are test
failures.
2016-12-21T20:33:38.759 [ERROR]
2016-12-21T20:33:38.759 [ERROR] Please refer to
<https://builds.apache.org/job/beam_PostCommit_Java_RunnableOnService_Gearpump/ws/runners/gearpump/target/surefire-reports>
for the individual test results.
2016-12-21T20:33:38.759 [ERROR] -> [Help 1]
org.apache.maven.lifecycle.LifecycleExecutionException: Failed to execute goal
org.apache.maven.plugins:maven-surefire-plugin:2.19.1:test
(runnable-on-service-tests) on project beam-runners-gearpump: There are test
failures.
Please refer to
<https://builds.apache.org/job/beam_PostCommit_Java_RunnableOnService_Gearpump/ws/runners/gearpump/target/surefire-reports>
for the individual test results.
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.jvnet.hudson.maven3.launcher.Maven32Launcher.main(Maven32Launcher.java:132)
at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
at
sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
at
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at
org.codehaus.plexus.classworlds.launcher.Launcher.launchStandard(Launcher.java:330)
at
org.codehaus.plexus.classworlds.launcher.Launcher.launch(Launcher.java:238)
at jenkins.maven3.agent.Maven32Main.launch(Maven32Main.java:186)
at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
at
sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
at
sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
at java.lang.reflect.Method.invoke(Method.java:498)
at hudson.maven.Maven3Builder.call(Maven3Builder.java:136)
at hudson.maven.Maven3Builder.call(Maven3Builder.java:71)
at hudson.remoting.UserRequest.perform(UserRequest.java:153)
at hudson.remoting.UserRequest.perform(UserRequest.java:50)
at hudson.remoting.Request$2.run(Request.java:332)
at
hudson.remoting.InterceptingExecutorService$1.call(InterceptingExecutorService.java:68)
at java.util.concurrent.FutureTask.run(FutureTask.java:266)
at
java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1142)
at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:617)
at java.lang.Thread.run(Thread.java:745)
Caused by: org.apache.maven.plugin.MojoFailureException: There are test
failures.
Please refer to
<https://builds.apache.org/job/beam_PostCommit_Java_RunnableOnService_Gearpump/ws/runners/gearpump/target/surefire-reports>
for the individual test results.
at
org.apache.maven.plugin.surefire.SurefireHelper.reportExecution(SurefireHelper.java:91)
at
org.apache.maven.plugin.surefire.SurefirePlugin.handleSummary(SurefirePlugin.java:320)
at
org.apache.maven.plugin.surefire.AbstractSurefireMojo.executeAfterPreconditionsChecked(AbstractSurefireMojo.java:892)
at
org.apache.maven.plugin.surefire.AbstractSurefireMojo.execute(AbstractSurefireMojo.java:755)
at
org.apache.maven.plugin.DefaultBuildPluginManager.executeMojo(DefaultBuildPluginManager.java:134)
at
org.apache.maven.lifecycle.internal.MojoExecutor.execute(MojoExecutor.java:208)
... 31 more
2016-12-21T20:33:38.760 [ERROR]
2016-12-21T20:33:38.760 [ERROR] Re-run Maven using the -X switch to enable full
debug logging.
2016-12-21T20:33:38.760 [ERROR]
2016-12-21T20:33:38.760 [ERROR] For more information about the errors and
possible solutions, please read the following articles:
2016-12-21T20:33:38.760 [ERROR] [Help 1]
http://cwiki.apache.org/confluence/display/MAVEN/MojoFailureException
2016-12-21T20:33:38.761 [ERROR]
2016-12-21T20:33:38.761 [ERROR] After correcting the problems, you can resume
the build with the command
2016-12-21T20:33:38.761 [ERROR] mvn <goals> -rf :beam-runners-gearpump
channel stopped