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 2018/10/23 22:35:48 UTC

Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Flink_Gradle #1952

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

Changes:

[kedin] [SQL] Move builtin aggregations creation to a map of factories

[kedin] [SQL] Simplify AggregationRel

[kedin] [SQL] Add AggregationCall wrapper

[kedin] [SQL] Inline aggregation rel helper transforms

[kedin] [SQL] Move CombineFn creation to AggregationCall constructor

[kedin] [SQL] Split and rename Aggregation CombineFn wrappers

[kedin] [SQL] Make AggregationCombineFnAdapter non-AutoValue

[kedin] [SQL] Convert ifs to guard statements in AggregationCombineFnAdapter

[kedin] [SQL] Convert Covariance to accept rows instead of KVs

[kedin] [SQL] Split Args Adapters from AggregationCombineFnAdapter

[kedin] [SQL] Extract MultipleAggregationFn from BeamAggregationTransforms

[kedin] [SQL] Clean up, comment aggregation transforms

------------------------------------------
[...truncated 53.92 MB...]
    INFO: No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService updateLeader
    INFO: Proposing leadership to contender org.apache.flink.runtime.jobmaster.JobManagerRunner@26dc7c5 @ akka://flink/user/jobmanager_269
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobManagerRunner verifyJobSchedulingStatusAndStartJobManager
    INFO: JobManager runner for job metricspushertest0test-jenkins-1023223531-b4747a58 (e7b3eac20f6df1fa2cd4946f5d9e09c2) was granted leadership with session id 0d0b76aa-ef88-429d-bc33-85f4e73ba518 at akka://flink/user/jobmanager_269.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobMaster startJobExecution
    INFO: Starting execution of job metricspushertest0test-jenkins-1023223531-b4747a58 (e7b3eac20f6df1fa2cd4946f5d9e09c2)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
    INFO: Job metricspushertest0test-jenkins-1023223531-b4747a58 (e7b3eac20f6df1fa2cd4946f5d9e09c2) switched from state CREATED to RUNNING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from CREATED to SCHEDULED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from CREATED to SCHEDULED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPool stashRequestWaitingForResourceManager
    INFO: Cannot serve slot request, no ResourceManager connected. Adding as pending request [SlotRequestId{d8a5023a4bcf5b7175bf6cb75a271fec}]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService confirmLeader
    INFO: Received confirmation of leadership for leader akka://flink/user/jobmanager_269 , session=0d0b76aa-ef88-429d-bc33-85f4e73ba518
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobMaster connectToResourceManager
    INFO: Connecting to ResourceManager akka://flink/user/resourcemanager_ab181320-2243-4ecf-af5b-76cd39571277(996bc109e96905e746ada5d503514b93)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.registration.RetryingRegistration lambda$startRegistration$0
    INFO: Resolved ResourceManager address, beginning registration
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.registration.RetryingRegistration register
    INFO: Registration at ResourceManager attempt 1 (timeout=100ms)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.ResourceManager registerJobManager
    INFO: Registering job manager bc3385f4e73ba5180d0b76aaef88429d@akka://flink/user/jobmanager_269 for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.ResourceManager registerJobMasterInternal
    INFO: Registered job manager bc3385f4e73ba5180d0b76aaef88429d@akka://flink/user/jobmanager_269 for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobMaster establishResourceManagerConnection
    INFO: JobManager successfully registered at ResourceManager, leader id: 996bc109e96905e746ada5d503514b93.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPool requestSlotFromResourceManager
    INFO: Requesting new slot [SlotRequestId{d8a5023a4bcf5b7175bf6cb75a271fec}] and profile ResourceProfile{cpuCores=-1.0, heapMemoryInMB=-1, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0} from resource manager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.ResourceManager requestSlot
    INFO: Request slot with profile ResourceProfile{cpuCores=-1.0, heapMemoryInMB=-1, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0} for job e7b3eac20f6df1fa2cd4946f5d9e09c2 with allocation id AllocationID{2efa8a7c30eb20407e911b859c04cf83}.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor requestSlot
    INFO: Receive slot request AllocationID{2efa8a7c30eb20407e911b859c04cf83} for job e7b3eac20f6df1fa2cd4946f5d9e09c2 from resource manager with leader id 996bc109e96905e746ada5d503514b93.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor requestSlot
    INFO: Allocated slot for AllocationID{2efa8a7c30eb20407e911b859c04cf83}.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.JobLeaderService addJob
    INFO: Add job e7b3eac20f6df1fa2cd4946f5d9e09c2 for job leader monitoring.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.JobLeaderService$JobManagerLeaderListener notifyLeaderAddress
    INFO: Try to register at job manager akka://flink/user/jobmanager_269 with leader id 0d0b76aa-ef88-429d-bc33-85f4e73ba518.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.registration.RetryingRegistration lambda$startRegistration$0
    INFO: Resolved JobManager address, beginning registration
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.registration.RetryingRegistration register
    INFO: Registration at JobManager attempt 1 (timeout=100ms)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.JobLeaderService$JobManagerLeaderListener$JobManagerRegisteredRpcConnection onRegistrationSuccess
    INFO: Successful registration at job manager akka://flink/user/jobmanager_269 for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor establishJobManagerConnection
    INFO: Establish JobManager connection for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor offerSlotsToJobManager
    INFO: Offer reserved slots to the leader of job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable markSlotActive
    INFO: Activate slot AllocationID{2efa8a7c30eb20407e911b859c04cf83}.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from SCHEDULED to DEPLOYING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution deploy
    INFO: Deploying Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (attempt #0) to localhost
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from SCHEDULED to DEPLOYING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution deploy
    INFO: Deploying GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (attempt #0) to localhost
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor submitTask
    INFO: Received task Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from CREATED to DEPLOYING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Creating FileSystem stream leak safety net for task Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) [DEPLOYING]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Loading JAR files for task Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) [DEPLOYING].
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor submitTask
    INFO: Received task GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Registering task at network: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) [DEPLOYING].
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from CREATED to DEPLOYING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Creating FileSystem stream leak safety net for task GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) [DEPLOYING]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Loading JAR files for task GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) [DEPLOYING].
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Registering task at network: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) [DEPLOYING].
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from DEPLOYING to RUNNING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.state.StateBackendLoader fromApplicationOrConfigOrDefault
    INFO: No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from DEPLOYING to RUNNING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from DEPLOYING to RUNNING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.state.StateBackendLoader fromApplicationOrConfigOrDefault
    INFO: No state backend has been configured, using default (Memory / JobManager) MemoryStateBackend (data in heap memory / checkpoints to JobManager) (checkpoints: 'null', savepoints: 'null', asynchronous: TRUE, maxStateSize: 5242880)
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from DEPLOYING to RUNNING.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.metrics.groups.TaskMetricGroup addOperator
    WARNING: The operator name GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) exceeded the 80 characters length limit and was truncated.
    Oct 23, 2018 10:35:32 PM org.apache.beam.runners.flink.translation.wrappers.streaming.io.UnboundedSourceWrapper initializeState
    INFO: No restore state for UnbounedSourceWrapper.
    Oct 23, 2018 10:35:32 PM org.apache.beam.runners.flink.translation.wrappers.streaming.io.UnboundedSourceWrapper open
    INFO: Unbounded Flink Source 0/1 is reading from sources: [org.apache.beam.runners.core.construction.UnboundedReadFromBoundedSource$BoundedToUnboundedSourceAdapter@5347717]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.state.heap.HeapKeyedStateBackend <init>
    INFO: Initializing heap keyed state backend with stream factory.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from RUNNING to FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Freeing task resources for Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Ensuring all FileSystem streams are closed for task Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) [FINISHED]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
    INFO: Un-registering task and sending final execution state FINISHED to JobManager for task Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem 601419308020fa6a4167b6d9b27c37b5.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from RUNNING to FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Freeing task resources for GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskmanager.Task run
    INFO: Ensuring all FileSystem streams are closed for task GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) [FINISHED]
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor unregisterTaskAndNotifyFinalState
    INFO: Un-registering task and sending final execution state FINISHED to JobManager for task GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) 829e6d6d8efd4311ce1a5dd4de0cfc2a.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: Source: GenerateSequence/Read(UnboundedCountingSource)/Create/Read(CreateSource) -> GenerateSequence/Read(UnboundedCountingSource)/Split/ParMultiDo(Split) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Pair with random key/ParMultiDo(AssignShard) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/Window.Into()/Window.Assign.out -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ReifyOriginalTimestamps/ParDo(Anonymous)/ParMultiDo(Anonymous) -> ToKeyedWorkItem (1/1) (601419308020fa6a4167b6d9b27c37b5) switched from RUNNING to FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.Execution transitionState
    INFO: GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/GroupByKey -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/ExpandIterable/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/ReifyTimestamps.RemoveWildcard/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Reshuffle/RestoreOriginalTimestamps/Reify.ExtractTimestampsFromValues/ParDo(Anonymous)/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Reshuffle/Values/Values/Map/ParMultiDo(Anonymous) -> GenerateSequence/Read(UnboundedCountingSource)/Read/ParMultiDo(Read) -> GenerateSequence/Read(UnboundedCountingSource)/StripIds/ParMultiDo(StripIds) -> ParDo(Counting)/ParMultiDo(Counting) (1/1) (829e6d6d8efd4311ce1a5dd4de0cfc2a) switched from RUNNING to FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.executiongraph.ExecutionGraph transitionState
    INFO: Job metricspushertest0test-jenkins-1023223531-b4747a58 (e7b3eac20f6df1fa2cd4946f5d9e09c2) switched from state RUNNING to FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.checkpoint.CheckpointCoordinator shutdown
    INFO: Stopping checkpoint coordinator for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore shutdown
    INFO: Shutting down
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.dispatcher.Dispatcher jobReachedGloballyTerminalState
    INFO: Job e7b3eac20f6df1fa2cd4946f5d9e09c2 reached globally terminal state FINISHED.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobMaster postStop
    INFO: Stopping the JobMaster for job metricspushertest0test-jenkins-1023223531-b4747a58(e7b3eac20f6df1fa2cd4946f5d9e09c2).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
    INFO: Close JobManager connection for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.JobMaster dissolveResourceManagerConnection
    INFO: Close ResourceManager connection 557fd37f25a8049bf67e941daf9b0d62: JobManager is shutting down..
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPool suspend
    INFO: Suspending SlotPool.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.ResourceManager closeJobManagerConnection
    INFO: Disconnect job manager bc3385f4e73ba5180d0b76aaef88429d@akka://flink/user/jobmanager_269 for job e7b3eac20f6df1fa2cd4946f5d9e09c2 from the resource manager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.jobmaster.slotpool.SlotPool postStop
    INFO: Stopping SlotPool.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable freeSlot
    INFO: Free slot TaskSlot(index:0, state:ALLOCATED, resource profile: ResourceProfile{cpuCores=1.0, heapMemoryInMB=42, directMemoryInMB=0, nativeMemoryInMB=0, networkMemoryInMB=0}, allocationId: AllocationID{2efa8a7c30eb20407e911b859c04cf83}, jobId: e7b3eac20f6df1fa2cd4946f5d9e09c2).
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor$JobLeaderListenerImpl jobManagerLostLeadership
    INFO: JobManager for job e7b3eac20f6df1fa2cd4946f5d9e09c2 with leader id bc3385f4e73ba5180d0b76aaef88429d lost leadership.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.registration.RetryingRegistration lambda$startRegistration$1
    INFO: Could not resolve JobManager address akka://flink/user/jobmanager_269, retrying in 10000 ms: Could not connect to rpc endpoint under address akka://flink/user/jobmanager_269..
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.JobLeaderService removeJob
    INFO: Remove job e7b3eac20f6df1fa2cd4946f5d9e09c2 from job leader monitoring.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.minicluster.MiniCluster closeAsync
    INFO: Shutting down Flink Mini Cluster
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
    INFO: Close JobManager connection for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.dispatcher.Dispatcher postStop
    INFO: Stopping dispatcher akka://flink/user/dispatcher0ea3cb40-c3ac-49d7-a354-f1e3a6b395e9.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.dispatcher.Dispatcher terminateJobManagerRunners
    INFO: Stopping all currently running jobs of dispatcher akka://flink/user/dispatcher0ea3cb40-c3ac-49d7-a354-f1e3a6b395e9.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.rest.RestServerEndpoint closeAsync
    INFO: Shutting down rest endpoint.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor closeJobManagerConnection
    INFO: Close JobManager connection for job e7b3eac20f6df1fa2cd4946f5d9e09c2.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor postStop
    INFO: Stopping TaskExecutor akka://flink/user/taskmanager_268.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager close
    INFO: Closing the SlotManager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager shutdown
    INFO: Shutting down TaskExecutorLocalStateStoresManager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager suspend
    INFO: Suspending the SlotManager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager unregisterTaskManager
    INFO: Unregister TaskManager b9400904f368ed3a237b95fb0292b9f6 from the SlotManager.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator shutDown
    INFO: Shutting down stack trace sample coordinator.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.dispatcher.Dispatcher lambda$postStop$0
    INFO: Stopped dispatcher akka://flink/user/dispatcher0ea3cb40-c3ac-49d7-a354-f1e3a6b395e9.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.io.disk.iomanager.IOManager shutdown
    INFO: I/O manager removed spill file directory /tmp/flink-io-448e14b1-4791-418e-b9a7-ec1cff771b01
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.io.network.NetworkEnvironment shutdown
    INFO: Shutting down the network environment and its components.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.JobLeaderService stop
    INFO: Stop job leader service.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.webmonitor.WebMonitorEndpoint lambda$shutDownInternal$4
    INFO: Removing cache directory /tmp/flink-web-ui
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.taskexecutor.TaskExecutor postStop
    INFO: Stopped TaskExecutor akka://flink/user/taskmanager_268.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService stopService
    INFO: Stopping Akka RPC service.
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.blob.AbstractBlobCache close
    INFO: Shutting down BLOB cache
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.blob.AbstractBlobCache close
    INFO: Shutting down BLOB cache
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.blob.BlobServer close
    INFO: Stopped BLOB server at 0.0.0.0:40905
    Oct 23, 2018 10:35:32 PM org.apache.flink.runtime.rpc.akka.AkkaRpcService lambda$stopService$4
    INFO: Stopped Akka RPC service.
    Oct 23, 2018 10:35:32 PM org.apache.beam.runners.flink.FlinkRunner createPipelineResult
    INFO: Execution finished in 315 msecs
    Oct 23, 2018 10:35:32 PM org.apache.beam.runners.flink.FlinkRunner createPipelineResult
    INFO: Final accumulator values:
    Oct 23, 2018 10:35:32 PM org.apache.beam.runners.flink.FlinkRunner createPipelineResult
    INFO: __metricscontainers : org.apache.beam.runners.core.metrics.MetricsContainerStepMap@71dae41c

Gradle Test Executor 4 finished executing tests.

> Task :beam-runners-flink_2.11:validatesRunnerStreaming
Finished generating test XML results (0.371 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Flink_Gradle/ws/src/runners/flink/build/test-results/validatesRunnerStreaming>
Generating HTML test report...
Finished generating test html results (0.363 secs) into: <https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Flink_Gradle/ws/src/runners/flink/build/reports/tests/validatesRunnerStreaming>
Packing task ':beam-runners-flink_2.11:validatesRunnerStreaming'
Invalidating in-memory cache of /home/jenkins/.gradle/caches/journal-1/file-access.bin
:beam-runners-flink_2.11:validatesRunnerStreaming (Thread[Task worker for ':' Thread 4,5,main]) completed. Took 2 mins 53.158 secs.

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11:validatesRunnerBatch'.
> Process 'Gradle Test Executor 2' finished with non-zero exit value 137
  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 15m 0s
48 actionable tasks: 44 executed, 4 from cache

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

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

Jenkins build is back to normal : beam_PostCommit_Java_ValidatesRunner_Flink_Gradle #1953

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