[GitHub] [flink] wangxlong opened a new pull request #14541: [FLINK-18778][table-planner] Support the SupportsProjectionPushDown i…

2021-01-02 Thread GitBox


wangxlong opened a new pull request #14541:
URL: https://github.com/apache/flink/pull/14541


   …nterface for LookupTableSource
   
   ## What is the purpose of the change
   
   LookupTableSource supports projection pushing down when implements 
SupportsProjectionPushDown interface.
   
   ## Brief change log
   
   Add rule `PushCalcIntoTemporalTableSourceRule ` to support projection push 
into temporal tableSource.
   And add some tests to verify this.
   
   ## Verifying this change
   
   This change added tests and can be verified as follows:
   1. Add PushCalcIntoTemporalTableSourceRuleTest class.
   2. Add some test method to LookupJoinTest, and some tests in LookupJoinTest 
also verify this.
   3. Some tests in LookupJoinITCase already verify this. 
   
   ## Does this pull request potentially affect one of the following parts:
   
 - Dependencies (does it add or upgrade a dependency): (no)
 - The public API, i.e., is any changed class annotated with 
`@Public(Evolving)`: (no)
 - The serializers: (no)
 - The runtime per-record code paths (performance sensitive): (no)
 - Anything that affects deployment or recovery: JobManager (and its 
components), Checkpointing, Kubernetes/Yarn/Mesos, ZooKeeper: (no)
 - The S3 file system connector: (no)
   
   ## Documentation
   
 - Does this pull request introduce a new feature? (no)
 - If yes, how is the feature documented? (not applicable / docs / JavaDocs 
/ not documented)
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] flinkbot edited a comment on pull request #14526: [FLINK-14814][WebUI] Highlight back pressured and busy nodes in the WebUI

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14526:
URL: https://github.com/apache/flink/pull/14526#issuecomment-752592411


   
   ## CI report:
   
   * 1bd73de4edd53b7a28cb9841518997e56caf6f9a Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11567)
 
   * 36c6736bfdc8ec1d28bedf3f36c8552415fda611 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11571)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[jira] [Closed] (FLINK-20798) Using PVC as high-availability.storageDir could not work

2021-01-02 Thread hayden zhou (Jira)


 [ 
https://issues.apache.org/jira/browse/FLINK-20798?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel
 ]

hayden zhou closed FLINK-20798.
---
Resolution: Fixed

> Using PVC as high-availability.storageDir could not work
> 
>
> Key: FLINK-20798
> URL: https://issues.apache.org/jira/browse/FLINK-20798
> Project: Flink
>  Issue Type: Bug
>  Components: Deployment / Kubernetes
>Affects Versions: 1.12.0
> Environment: FLINK 1.12.0
>Reporter: hayden zhou
>Priority: Major
> Attachments: flink.log
>
>
> 我这边 部署 flink 到 k8s 使用 PVC 作为 high avalibility storagedir , 我看jobmanager 
> 的日志,选举成功了。但是 web 一直显示选举进行中。
> When deploying standalone Flink on Kubernetes and configure the 
> {{high-availability.storageDir}} to a mounted PVC directory, the Flink webui 
> could not be visited normally. It shows that "Service temporarily unavailable 
> due to an ongoing leader election. Please refresh".
>  
> 下面是 jobmanager 的日志
> The following is related logs from JobManager.
> {code}
> 2020-12-29T06:45:54.177850394Z 2020-12-29 14:45:54,177 DEBUG 
> io.fabric8.kubernetes.client.extended.leaderelection.LeaderElector [] - 
> Leader election started
>  2020-12-29T06:45:54.177855303Z 2020-12-29 14:45:54,177 DEBUG 
> io.fabric8.kubernetes.client.extended.leaderelection.LeaderElector [] - 
> Attempting to acquire leader lease 'ConfigMapLock: default - 
> mta-flink-resourcemanager-leader (6f6479c6-86cc-4d62-84f9-37ff968bd0e5)'...
>  2020-12-29T06:45:54.178668055Z 2020-12-29 14:45:54,178 DEBUG 
> io.fabric8.kubernetes.client.dsl.internal.WatchConnectionManager [] - 
> WebSocket successfully opened
>  2020-12-29T06:45:54.178895963Z 2020-12-29 14:45:54,178 INFO 
> org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService [] - 
> Starting DefaultLeaderRetrievalService with 
> KubernetesLeaderRetrievalDriver\{configMapName='mta-flink-resourcemanager-leader'}.
>  2020-12-29T06:45:54.179327491Z 2020-12-29 14:45:54,179 DEBUG 
> io.fabric8.kubernetes.client.dsl.internal.WatchConnectionManager [] - 
> Connecting websocket ... 
> io.fabric8.kubernetes.client.dsl.internal.WatchConnectionManager@6d303498
>  2020-12-29T06:45:54.230081993Z 2020-12-29 14:45:54,229 DEBUG 
> io.fabric8.kubernetes.client.dsl.internal.WatchConnectionManager [] - 
> WebSocket successfully opened
>  2020-12-29T06:45:54.230202329Z 2020-12-29 14:45:54,230 INFO 
> org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService [] - 
> Starting DefaultLeaderRetrievalService with 
> KubernetesLeaderRetrievalDriver\{configMapName='mta-flink-dispatcher-leader'}.
>  2020-12-29T06:45:54.230219281Z 2020-12-29 14:45:54,229 DEBUG 
> io.fabric8.kubernetes.client.dsl.internal.WatchConnectionManager [] - 
> WebSocket successfully opened
>  2020-12-29T06:45:54.230353912Z 2020-12-29 14:45:54,230 INFO 
> org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService [] - 
> Starting DefaultLeaderElectionService with 
> KubernetesLeaderElectionDriver\{configMapName='mta-flink-resourcemanager-leader'}.
>  2020-12-29T06:45:54.237004177Z 2020-12-29 14:45:54,236 DEBUG 
> io.fabric8.kubernetes.client.extended.leaderelection.LeaderElector [] - 
> Leader changed from null to 6f6479c6-86cc-4d62-84f9-37ff968bd0e5
>  2020-12-29T06:45:54.237024655Z 2020-12-29 14:45:54,236 INFO 
> org.apache.flink.kubernetes.kubeclient.resources.KubernetesLeaderElector [] - 
> New leader elected 6f6479c6-86cc-4d62-84f9-37ff968bd0e5 for 
> mta-flink-restserver-leader.
>  2020-12-29T06:45:54.237027811Z 2020-12-29 14:45:54,236 DEBUG 
> io.fabric8.kubernetes.client.extended.leaderelection.LeaderElector [] - 
> Successfully Acquired leader lease 'ConfigMapLock: default - 
> mta-flink-restserver-leader (6f6479c6-86cc-4d62-84f9-37ff968bd0e5)'
>  2020-12-29T06:45:54.237297376Z 2020-12-29 14:45:54,237 DEBUG 
> org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService [] - 
> Grant leadership to contender 
> [http://mta-flink-jobmanager:8081|http://mta-flink-jobmanager:8081/] with 
> session ID 9587e13f-322f-4cd5-9fff-b4941462be0f.
>  2020-12-29T06:45:54.237353551Z 2020-12-29 14:45:54,237 INFO 
> org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint [] - 
> [http://mta-flink-jobmanager:8081|http://mta-flink-jobmanager:8081/] was 
> granted leadership with leaderSessionID=9587e13f-322f-4cd5-9fff-b4941462be0f
>  2020-12-29T06:45:54.237440354Z 2020-12-29 14:45:54,237 DEBUG 
> org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService [] - 
> Confirm leader session ID 9587e13f-322f-4cd5-9fff-b4941462be0f for leader 
> [http://mta-flink-jobmanager:8081|http://mta-flink-jobmanager:8081/].
>  2020-12-29T06:45:54.254555127Z 2020-12-29 14:45:54,254 DEBUG 
> io.fabric8.kubernetes.client.extended.leaderelection.LeaderElector [] - 
> Leader changed from null to 

[GitHub] [flink] flinkbot edited a comment on pull request #14526: [FLINK-14814][WebUI] Highlight back pressured and busy nodes in the WebUI

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14526:
URL: https://github.com/apache/flink/pull/14526#issuecomment-752592411


   
   ## CI report:
   
   * 1bd73de4edd53b7a28cb9841518997e56caf6f9a Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11567)
 
   * 36c6736bfdc8ec1d28bedf3f36c8552415fda611 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[jira] [Commented] (FLINK-20811) Support HTTP paths for yarn ship files/archives

2021-01-02 Thread Zhenqiu Huang (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-20811?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257677#comment-17257677
 ] 

Zhenqiu Huang commented on FLINK-20811:
---

[~fly_in_gis]
Echo to Xintong's questions. If the variable userJars in a Jobgraph has a jar 
with Http path (It could be set by user configuration for example 
pipeline.jars), it will be added it as LocalResource in Yarn. How K8 handle the 
Http libs needed in runtime?

> Support HTTP paths for yarn ship files/archives
> ---
>
> Key: FLINK-20811
> URL: https://issues.apache.org/jira/browse/FLINK-20811
> Project: Flink
>  Issue Type: New Feature
>  Components: Deployment / YARN
>Reporter: Xintong Song
>Priority: Major
>
> Flink's Yarn integration supports shipping workload-specific local 
> files/directories/archives to the Yarn cluster.
> As discussed in FLINK-20505, it would be helpful to support directly 
> downloading contents from HTTP paths to the Yarn cluster, so that users won't 
> need to first download the contents locally and then upload it to the Yarn 
> cluster.
>  



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Updated] (FLINK-20830) Add a type of HEADLESS_CLUSTER_IP for rest service type

2021-01-02 Thread Aitozi (Jira)


 [ 
https://issues.apache.org/jira/browse/FLINK-20830?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel
 ]

Aitozi updated FLINK-20830:
---
Description: Now we can choose ClusterIP or NodePort or LoadBalancer as 
rest service type. But in our internal kubernetes cluster, there is no 
kube-proxy, and ClusterIP mode rely on kube-proxy. So I think can we support 
another type of HEADLESS_CLUSTER_IP to directly talk to jobmanager pod? cc 
[~fly_in_gis]  (was: Now we can choose ClusterIP or NodePort or LoadBalancer as 
rest service type. But in our internal kubernetes cluster, there is no 
kube-proxy, and ClusterIP mode rely on kube-proxy. So I think we can support 
another type of HEADLESS_CLUSTER_IP to directly talk to jobmanager pod, what's 
your suggestion? cc [~fly_in_gis])

> Add a type of HEADLESS_CLUSTER_IP for rest service type
> ---
>
> Key: FLINK-20830
> URL: https://issues.apache.org/jira/browse/FLINK-20830
> Project: Flink
>  Issue Type: Improvement
>  Components: Deployment / Kubernetes
>Reporter: Aitozi
>Priority: Major
>
> Now we can choose ClusterIP or NodePort or LoadBalancer as rest service type. 
> But in our internal kubernetes cluster, there is no kube-proxy, and ClusterIP 
> mode rely on kube-proxy. So I think can we support another type of 
> HEADLESS_CLUSTER_IP to directly talk to jobmanager pod? cc [~fly_in_gis]



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Created] (FLINK-20830) Add a type of HEADLESS_CLUSTER_IP for rest service type

2021-01-02 Thread Aitozi (Jira)
Aitozi created FLINK-20830:
--

 Summary: Add a type of HEADLESS_CLUSTER_IP for rest service type
 Key: FLINK-20830
 URL: https://issues.apache.org/jira/browse/FLINK-20830
 Project: Flink
  Issue Type: Improvement
  Components: Deployment / Kubernetes
Reporter: Aitozi


Now we can choose ClusterIP or NodePort or LoadBalancer as rest service type. 
But in our internal kubernetes cluster, there is no kube-proxy, and ClusterIP 
mode rely on kube-proxy. So I think we can support another type of 
HEADLESS_CLUSTER_IP to directly talk to jobmanager pod, what's your suggestion? 
cc [~fly_in_gis]



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Commented] (FLINK-20309) UnalignedCheckpointTestBase.execute is failed

2021-01-02 Thread Huang Xingbo (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-20309?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257649#comment-17257649
 ] 

Huang Xingbo commented on FLINK-20309:
--

https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11570=logs=39d5b1d5-3b41-54dc-6458-1e2ddd1cdcf3=a99e99c7-21cd-5a1f-7274-585e62b72f56

> UnalignedCheckpointTestBase.execute is failed
> -
>
> Key: FLINK-20309
> URL: https://issues.apache.org/jira/browse/FLINK-20309
> Project: Flink
>  Issue Type: Bug
>  Components: Runtime / Checkpointing
>Affects Versions: 1.12.0, 1.13.0
>Reporter: Jark Wu
>Assignee: Arvid Heise
>Priority: Blocker
>  Labels: pull-request-available, test-stability
> Fix For: 1.12.0, 1.13.0
>
>
> https://dev.azure.com/imjark/Flink/_build/results?buildId=345=logs=0a15d512-44ac-5ba5-97ab-13a5d066c22c=634cd701-c189-5dff-24cb-606ed884db87
> {code}
> [ERROR] Failures: 
> [ERROR] 
> org.apache.flink.test.checkpointing.UnalignedCheckpointITCase.execute[Parallel
>  cogroup, p = 
> 10](org.apache.flink.test.checkpointing.UnalignedCheckpointITCase)
> [ERROR]   Run 1: 
> UnalignedCheckpointITCase.execute:153->UnalignedCheckpointTestBase.execute:123
>  NUM_OUT_OF_ORDER
> Expected: <0L>
>  but: was <10063L>
> [ERROR]   Run 2: 
> UnalignedCheckpointITCase.execute:153->UnalignedCheckpointTestBase.execute:125
>  NUM_LOST
> Expected: <0L>
>  but: was <10037L>
> [INFO] 
> [INFO] 
> [ERROR] Tests run: 1592, Failures: 1, Errors: 0, Skipped: 44
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Commented] (FLINK-20781) UnalignedCheckpointITCase failure caused by NullPointerException

2021-01-02 Thread Huang Xingbo (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-20781?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257648#comment-17257648
 ] 

Huang Xingbo commented on FLINK-20781:
--

https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11568=logs=5c8e7682-d68f-54d1-16a2-a09310218a49=f508e270-48d6-5f1e-3138-42a17e0714f0

> UnalignedCheckpointITCase failure caused by NullPointerException
> 
>
> Key: FLINK-20781
> URL: https://issues.apache.org/jira/browse/FLINK-20781
> Project: Flink
>  Issue Type: Bug
>Affects Versions: 1.12.0, 1.13.0
>Reporter: Matthias
>Assignee: Jiangjie Qin
>Priority: Critical
>  Labels: test-stability
> Fix For: 1.12.1
>
>
> {{UnalignedCheckpointITCase}} fails due to {{NullPointerException}} (e.g. in 
> [this 
> build|https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11083=logs=59c257d0-c525-593b-261d-e96a86f1926b=b93980e3-753f-5433-6a19-13747adae66a=8798]):
> {code:java}
> [ERROR] Tests run: 10, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 
> 152.186 s <<< FAILURE! - in 
> org.apache.flink.test.checkpointing.UnalignedCheckpointITCase
> [ERROR] execute[Parallel cogroup, p = 
> 10](org.apache.flink.test.checkpointing.UnalignedCheckpointITCase)  Time 
> elapsed: 34.869 s  <<< ERROR!
> org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
>   at 
> org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:147)
>   at 
> org.apache.flink.runtime.minicluster.MiniClusterJobClient.lambda$getJobExecutionResult$2(MiniClusterJobClient.java:119)
>   at 
> java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
>   at 
> java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
>   at 
> java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
>   at 
> java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
>   at 
> org.apache.flink.runtime.rpc.akka.AkkaInvocationHandler.lambda$invokeRpc$0(AkkaInvocationHandler.java:229)
>   at 
> java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
>   at 
> java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
>   at 
> java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
>   at 
> java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
>   at 
> org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:996)
>   at akka.dispatch.OnComplete.internal(Future.scala:264)
>   at akka.dispatch.OnComplete.internal(Future.scala:261)
>   at akka.dispatch.japi$CallbackBridge.apply(Future.scala:191)
>   at akka.dispatch.japi$CallbackBridge.apply(Future.scala:188)
>   at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
>   at 
> org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:74)
>   at 
> scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
>   at 
> scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
>   at akka.pattern.PromiseActorRef.$bang(AskSupport.scala:572)
>   at 
> akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:22)
>   at 
> akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:21)
>   at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:436)
>   at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:435)
>   at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
>   at 
> akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:55)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply$mcV$sp(BatchingExecutor.scala:91)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
>   at 
> scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:72)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:90)
>   at akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:40)
>   at 
> akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:44)
>   at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
>   at 
> akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
>   at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
>   at 
> 

[GitHub] [flink] flinkbot edited a comment on pull request #14526: [FLINK-14814][WebUI] Highlight back pressured and busy nodes in the WebUI

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14526:
URL: https://github.com/apache/flink/pull/14526#issuecomment-752592411


   
   ## CI report:
   
   * 1bd73de4edd53b7a28cb9841518997e56caf6f9a Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11567)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] flinkbot edited a comment on pull request #14526: [FLINK-14814][WebUI] Highlight back pressured and busy nodes in the WebUI

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14526:
URL: https://github.com/apache/flink/pull/14526#issuecomment-752592411


   
   ## CI report:
   
   * 9c058a5518d886948980c0df71bbfa58a12ff969 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11561)
 
   * 1bd73de4edd53b7a28cb9841518997e56caf6f9a Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11567)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] flinkbot edited a comment on pull request #14526: [FLINK-14814][WebUI] Highlight back pressured and busy nodes in the WebUI

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14526:
URL: https://github.com/apache/flink/pull/14526#issuecomment-752592411


   
   ## CI report:
   
   * 9c058a5518d886948980c0df71bbfa58a12ff969 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11561)
 
   * 1bd73de4edd53b7a28cb9841518997e56caf6f9a UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] flinkbot edited a comment on pull request #8418: [FLINK-12491][docs][configuration] Fix incorrect javadoc for path sep…

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #8418:
URL: https://github.com/apache/flink/pull/8418#issuecomment-748479166


   
   ## CI report:
   
   * 8a6f4f985c8cc16556938db6763db4067d54458b Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11560)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] flinkbot edited a comment on pull request #8418: [FLINK-12491][docs][configuration] Fix incorrect javadoc for path sep…

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #8418:
URL: https://github.com/apache/flink/pull/8418#issuecomment-748479166


   
   ## CI report:
   
   * 8a6f4f985c8cc16556938db6763db4067d54458b Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11560)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] kezhuw commented on pull request #8418: [FLINK-12491][docs][configuration] Fix incorrect javadoc for path sep…

2021-01-02 Thread GitBox


kezhuw commented on pull request #8418:
URL: https://github.com/apache/flink/pull/8418#issuecomment-753472104


   @flinkbot run azure



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[jira] [Closed] (FLINK-20828) Fix some aggregate and flat_aggregate tests failed in py35

2021-01-02 Thread Dian Fu (Jira)


 [ 
https://issues.apache.org/jira/browse/FLINK-20828?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel
 ]

Dian Fu closed FLINK-20828.
---
  Assignee: Huang Xingbo
Resolution: Fixed

Fixed in master via bab7632e0c145780eef08e2bf42d4af3ef8ad8b3

> Fix some aggregate and flat_aggregate tests failed in py35
> --
>
> Key: FLINK-20828
> URL: https://issues.apache.org/jira/browse/FLINK-20828
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python
>Affects Versions: 1.13.0
>Reporter: Huang Xingbo
>Assignee: Huang Xingbo
>Priority: Critical
>  Labels: pull-request-available, test-stability
> Fix For: 1.13.0
>
>
> We need to fix some aggregate/flat_aggregate tests due to FLINK-20769 , which 
> cased the difference of result oder.
> These tests include:
> pyflink/table/tests/test_row_based_operation.py::StreamRowBasedOperationITTests::test_aggregate
> pyflink/table/tests/test_row_based_operation.py::StreamRowBasedOperationITTests::test_flat_aggregate_list_view
> pyflink/table/tests/test_udaf.py::StreamTableAggregateTests::test_list_view
> pyflink/table/tests/test_udaf.py::StreamTableAggregateTests::test_map_view_iterate



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[GitHub] [flink] dianfu merged pull request #14540: [FLINK-20828][python] Fix some aggregate and flat_aggregate tests failed in py35

2021-01-02 Thread GitBox


dianfu merged pull request #14540:
URL: https://github.com/apache/flink/pull/14540


   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[jira] [Commented] (FLINK-20781) UnalignedCheckpointITCase failure caused by NullPointerException

2021-01-02 Thread Huang Xingbo (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-20781?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257333#comment-17257333
 ] 

Huang Xingbo commented on FLINK-20781:
--

https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11564=logs=119bbba7-f5e3-5e08-e72d-09f1529665de=7dc1f5a9-54e1-502e-8b02-c7df69073cfc

> UnalignedCheckpointITCase failure caused by NullPointerException
> 
>
> Key: FLINK-20781
> URL: https://issues.apache.org/jira/browse/FLINK-20781
> Project: Flink
>  Issue Type: Bug
>Affects Versions: 1.12.0, 1.13.0
>Reporter: Matthias
>Assignee: Jiangjie Qin
>Priority: Critical
>  Labels: test-stability
> Fix For: 1.12.1
>
>
> {{UnalignedCheckpointITCase}} fails due to {{NullPointerException}} (e.g. in 
> [this 
> build|https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11083=logs=59c257d0-c525-593b-261d-e96a86f1926b=b93980e3-753f-5433-6a19-13747adae66a=8798]):
> {code:java}
> [ERROR] Tests run: 10, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 
> 152.186 s <<< FAILURE! - in 
> org.apache.flink.test.checkpointing.UnalignedCheckpointITCase
> [ERROR] execute[Parallel cogroup, p = 
> 10](org.apache.flink.test.checkpointing.UnalignedCheckpointITCase)  Time 
> elapsed: 34.869 s  <<< ERROR!
> org.apache.flink.runtime.client.JobExecutionException: Job execution failed.
>   at 
> org.apache.flink.runtime.jobmaster.JobResult.toJobExecutionResult(JobResult.java:147)
>   at 
> org.apache.flink.runtime.minicluster.MiniClusterJobClient.lambda$getJobExecutionResult$2(MiniClusterJobClient.java:119)
>   at 
> java.util.concurrent.CompletableFuture.uniApply(CompletableFuture.java:616)
>   at 
> java.util.concurrent.CompletableFuture$UniApply.tryFire(CompletableFuture.java:591)
>   at 
> java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
>   at 
> java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
>   at 
> org.apache.flink.runtime.rpc.akka.AkkaInvocationHandler.lambda$invokeRpc$0(AkkaInvocationHandler.java:229)
>   at 
> java.util.concurrent.CompletableFuture.uniWhenComplete(CompletableFuture.java:774)
>   at 
> java.util.concurrent.CompletableFuture$UniWhenComplete.tryFire(CompletableFuture.java:750)
>   at 
> java.util.concurrent.CompletableFuture.postComplete(CompletableFuture.java:488)
>   at 
> java.util.concurrent.CompletableFuture.complete(CompletableFuture.java:1975)
>   at 
> org.apache.flink.runtime.concurrent.FutureUtils$1.onComplete(FutureUtils.java:996)
>   at akka.dispatch.OnComplete.internal(Future.scala:264)
>   at akka.dispatch.OnComplete.internal(Future.scala:261)
>   at akka.dispatch.japi$CallbackBridge.apply(Future.scala:191)
>   at akka.dispatch.japi$CallbackBridge.apply(Future.scala:188)
>   at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
>   at 
> org.apache.flink.runtime.concurrent.Executors$DirectExecutionContext.execute(Executors.java:74)
>   at 
> scala.concurrent.impl.CallbackRunnable.executeWithValue(Promise.scala:44)
>   at 
> scala.concurrent.impl.Promise$DefaultPromise.tryComplete(Promise.scala:252)
>   at akka.pattern.PromiseActorRef.$bang(AskSupport.scala:572)
>   at 
> akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:22)
>   at 
> akka.pattern.PipeToSupport$PipeableFuture$$anonfun$pipeTo$1.applyOrElse(PipeToSupport.scala:21)
>   at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:436)
>   at scala.concurrent.Future$$anonfun$andThen$1.apply(Future.scala:435)
>   at scala.concurrent.impl.CallbackRunnable.run(Promise.scala:36)
>   at 
> akka.dispatch.BatchingExecutor$AbstractBatch.processBatch(BatchingExecutor.scala:55)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply$mcV$sp(BatchingExecutor.scala:91)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch$$anonfun$run$1.apply(BatchingExecutor.scala:91)
>   at 
> scala.concurrent.BlockContext$.withBlockContext(BlockContext.scala:72)
>   at 
> akka.dispatch.BatchingExecutor$BlockableBatch.run(BatchingExecutor.scala:90)
>   at akka.dispatch.TaskInvocation.run(AbstractDispatcher.scala:40)
>   at 
> akka.dispatch.ForkJoinExecutorConfigurator$AkkaForkJoinTask.exec(ForkJoinExecutorConfigurator.scala:44)
>   at akka.dispatch.forkjoin.ForkJoinTask.doExec(ForkJoinTask.java:260)
>   at 
> akka.dispatch.forkjoin.ForkJoinPool$WorkQueue.runTask(ForkJoinPool.java:1339)
>   at akka.dispatch.forkjoin.ForkJoinPool.runWorker(ForkJoinPool.java:1979)
>   at 
> 

[jira] [Commented] (FLINK-18634) FlinkKafkaProducerITCase.testRecoverCommittedTransaction failed with "Timeout expired after 60000milliseconds while awaiting InitProducerId"

2021-01-02 Thread Huang Xingbo (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-18634?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257332#comment-17257332
 ] 

Huang Xingbo commented on FLINK-18634:
--

[https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=11564=logs=72d4811f-9f0d-5fd0-014a-0bc26b72b642=c1d93a6a-ba91-515d-3196-2ee8019fbda7]

 

> FlinkKafkaProducerITCase.testRecoverCommittedTransaction failed with "Timeout 
> expired after 6milliseconds while awaiting InitProducerId"
> 
>
> Key: FLINK-18634
> URL: https://issues.apache.org/jira/browse/FLINK-18634
> Project: Flink
>  Issue Type: Bug
>  Components: Connectors / Kafka, Tests
>Affects Versions: 1.11.0, 1.12.0, 1.13.0
>Reporter: Dian Fu
>Priority: Major
>  Labels: test-stability
>
> https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=4590=logs=c5f0071e-1851-543e-9a45-9ac140befc32=684b1416-4c17-504e-d5ab-97ee44e08a20
> {code}
> 2020-07-17T11:43:47.9693015Z [ERROR] Tests run: 12, Failures: 0, Errors: 1, 
> Skipped: 0, Time elapsed: 269.399 s <<< FAILURE! - in 
> org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerITCase
> 2020-07-17T11:43:47.9693862Z [ERROR] 
> testRecoverCommittedTransaction(org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerITCase)
>   Time elapsed: 60.679 s  <<< ERROR!
> 2020-07-17T11:43:47.9694737Z org.apache.kafka.common.errors.TimeoutException: 
> org.apache.kafka.common.errors.TimeoutException: Timeout expired after 
> 6milliseconds while awaiting InitProducerId
> 2020-07-17T11:43:47.9695376Z Caused by: 
> org.apache.kafka.common.errors.TimeoutException: Timeout expired after 
> 6milliseconds while awaiting InitProducerId
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[jira] [Commented] (FLINK-20309) UnalignedCheckpointTestBase.execute is failed

2021-01-02 Thread Huang Xingbo (Jira)


[ 
https://issues.apache.org/jira/browse/FLINK-20309?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17257331#comment-17257331
 ] 

Huang Xingbo commented on FLINK-20309:
--

[https://dev.azure.com/hxbks2ks/FLINK-TEST/_build/results?buildId=734=logs=6e55a443-5252-5db5-c632-109baf464772=9df6efca-61d0-513a-97ad-edb76d85786a]

Same test failed in my private Azure pipeline

> UnalignedCheckpointTestBase.execute is failed
> -
>
> Key: FLINK-20309
> URL: https://issues.apache.org/jira/browse/FLINK-20309
> Project: Flink
>  Issue Type: Bug
>  Components: Runtime / Checkpointing
>Affects Versions: 1.12.0, 1.13.0
>Reporter: Jark Wu
>Assignee: Arvid Heise
>Priority: Blocker
>  Labels: pull-request-available, test-stability
> Fix For: 1.12.0, 1.13.0
>
>
> https://dev.azure.com/imjark/Flink/_build/results?buildId=345=logs=0a15d512-44ac-5ba5-97ab-13a5d066c22c=634cd701-c189-5dff-24cb-606ed884db87
> {code}
> [ERROR] Failures: 
> [ERROR] 
> org.apache.flink.test.checkpointing.UnalignedCheckpointITCase.execute[Parallel
>  cogroup, p = 
> 10](org.apache.flink.test.checkpointing.UnalignedCheckpointITCase)
> [ERROR]   Run 1: 
> UnalignedCheckpointITCase.execute:153->UnalignedCheckpointTestBase.execute:123
>  NUM_OUT_OF_ORDER
> Expected: <0L>
>  but: was <10063L>
> [ERROR]   Run 2: 
> UnalignedCheckpointITCase.execute:153->UnalignedCheckpointTestBase.execute:125
>  NUM_LOST
> Expected: <0L>
>  but: was <10037L>
> [INFO] 
> [INFO] 
> [ERROR] Tests run: 1592, Failures: 1, Errors: 0, Skipped: 44
> {code}



--
This message was sent by Atlassian Jira
(v8.3.4#803005)


[GitHub] [flink] flinkbot edited a comment on pull request #14540: [FLINK-20828][python] Fix some aggregate and flat_aggregate tests failed in py35

2021-01-02 Thread GitBox


flinkbot edited a comment on pull request #14540:
URL: https://github.com/apache/flink/pull/14540#issuecomment-753434383


   
   ## CI report:
   
   * 7af04a4cc427492bc4ef53e362e9ef6d9decc820 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=11565)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot run travis` re-run the last Travis build
- `@flinkbot run azure` re-run the last Azure build
   



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org




[GitHub] [flink] HuangXingBo commented on pull request #14540: [FLINK-20828][python] Fix some aggregate and flat_aggregate tests failed in py35

2021-01-02 Thread GitBox


HuangXingBo commented on pull request #14540:
URL: https://github.com/apache/flink/pull/14540#issuecomment-753453861


   Tests passed in all supported versions
   
https://dev.azure.com/hxbks2ks/FLINK-TEST/_build/results?buildId=734=logs=fba17979-6d2e-591d-72f1-97cf42797c11=443dc6bf-b240-56df-6acf-c882d4b238da



This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org