[GitHub] [flink] flinkbot commented on issue #11807: [FLINK-16113][table-planner-blink] ExpressionReducer shouldn't escape…

2020-04-19 Thread GitBox
flinkbot commented on issue #11807: [FLINK-16113][table-planner-blink] 
ExpressionReducer shouldn't escape…
URL: https://github.com/apache/flink/pull/11807#issuecomment-616061874
 
 
   
   ## CI report:
   
   * 3a7f515b35e2a2ffba69fe45438b67c96c16525c 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


With regards,
Apache Git Services


[GitHub] [flink] zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] Throw fatal error in KubernetesResourceManager when the pods watcher is closed with exception

2020-04-19 Thread GitBox
zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] 
Throw fatal error in KubernetesResourceManager when the pods watcher is closed 
with exception
URL: https://github.com/apache/flink/pull/11010#discussion_r410823754
 
 

 ##
 File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/KubernetesResourceManager.java
 ##
 @@ -148,6 +156,7 @@ protected void initialize() throws 
ResourceManagerException {
Throwable exception = null;
 
try {
+   podsWatch.close();
 
 Review comment:
   If an Exception is thrown by `podsWatch.close`, `kubeClient.close` would not 
be called. I think it would be better to separately enclose them into different 
try-catch blocks.


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


With regards,
Apache Git Services


[GitHub] [flink] zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] Throw fatal error in KubernetesResourceManager when the pods watcher is closed with exception

2020-04-19 Thread GitBox
zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] 
Throw fatal error in KubernetesResourceManager when the pods watcher is closed 
with exception
URL: https://github.com/apache/flink/pull/11010#discussion_r410822987
 
 

 ##
 File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/KubernetesResourceManager.java
 ##
 @@ -91,6 +93,8 @@
/** The number of pods requested, but not yet granted. */
private int numPendingPodRequests = 0;
 
+   private KubernetesWatch podsWatch;
 
 Review comment:
   What are the benefits to wrap all the Kubernetes components we use? 
Currently, I have seen the `KubernetesPod`, `KubernetesResource`, 
`KubernetesService`, and `KubernetesToleration` already. Can we just remove 
such kind of wrappers?


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


With regards,
Apache Git Services


[GitHub] [flink] xintongsong commented on a change in pull request #11323: [FLINK-16439][k8s] Make KubernetesResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
xintongsong commented on a change in pull request #11323: [FLINK-16439][k8s] 
Make KubernetesResourceManager starts workers using WorkerResourceSpec 
requested by SlotManager
URL: https://github.com/apache/flink/pull/11323#discussion_r410838053
 
 

 ##
 File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/KubernetesResourceManager.java
 ##
 @@ -237,57 +230,73 @@ private void recoverWorkerNodesFromPreviousAttempts() 
throws ResourceManagerExce
++currentMaxAttemptId);
}
 
-   private void requestKubernetesPod() {
-   numPendingPodRequests++;
+   private void requestKubernetesPod(WorkerResourceSpec 
workerResourceSpec) {
+   final KubernetesTaskManagerParameters parameters =
+   
createKubernetesTaskManagerParameters(workerResourceSpec);
+
+   final KubernetesPod taskManagerPod =
+   
KubernetesTaskManagerFactory.createTaskManagerComponent(parameters);
+   kubeClient.createTaskManagerPod(taskManagerPod);
+
+   podWorkerResources.put(parameters.getPodName(), 
workerResourceSpec);
+   final int pendingWorkerNum = 
notifyNewWorkerRequested(workerResourceSpec);
 
log.info("Requesting new TaskManager pod with <{},{}>. Number 
pending requests {}.",
-   defaultMemoryMB,
-   defaultCpus,
-   numPendingPodRequests);
+   parameters.getTaskManagerMemoryMB(),
+   parameters.getTaskManagerCPU(),
+   pendingWorkerNum);
+   log.info("TaskManager {} will be started with {}.", 
parameters.getPodName(), workerResourceSpec);
+   }
+
+   private KubernetesTaskManagerParameters 
createKubernetesTaskManagerParameters(WorkerResourceSpec workerResourceSpec) {
+   final TaskExecutorProcessSpec taskExecutorProcessSpec =
+   
TaskExecutorProcessUtils.processSpecFromWorkerResourceSpec(flinkConfig, 
workerResourceSpec);
 
final String podName = String.format(
TASK_MANAGER_POD_FORMAT,
clusterId,
currentMaxAttemptId,
++currentMaxPodId);
 
+   final ContaineredTaskManagerParameters taskManagerParameters =
+   ContaineredTaskManagerParameters.create(flinkConfig, 
taskExecutorProcessSpec);
+
final String dynamicProperties =

BootstrapTools.getDynamicPropertiesAsString(flinkClientConfig, flinkConfig);
 
-   final KubernetesTaskManagerParameters 
kubernetesTaskManagerParameters = new KubernetesTaskManagerParameters(
+   return new KubernetesTaskManagerParameters(
flinkConfig,
podName,
dynamicProperties,
taskManagerParameters);
-
-   final KubernetesPod taskManagerPod =
-   
KubernetesTaskManagerFactory.createTaskManagerComponent(kubernetesTaskManagerParameters);
-
-   log.info("TaskManager {} will be started with {}.", podName, 
taskExecutorProcessSpec);
-   kubeClient.createTaskManagerPod(taskManagerPod);
}
 
/**
 * Request new pod if pending pods cannot satisfy pending slot requests.
 */
-   private void requestKubernetesPodIfRequired() {
-   final int requiredTaskManagers = 
getNumberRequiredTaskManagers();
+   private void requestKubernetesPodIfRequired(WorkerResourceSpec 
workerResourceSpec) {
+   final int pendingWorkerNum = 
getNumPendingWorkersFor(workerResourceSpec);
+   int requiredTaskManagers = 
getRequiredResources().get(workerResourceSpec);
 
-   while (requiredTaskManagers > numPendingPodRequests) {
-   requestKubernetesPod();
+   while (requiredTaskManagers-- > pendingWorkerNum) {
+   requestKubernetesPod(workerResourceSpec);
}
}
 
private void removePodIfTerminated(KubernetesPod pod) {
if (pod.isTerminated()) {
kubeClient.stopPod(pod.getName());
 
 Review comment:
   Thanks all for the feedbacks and good discussion.
   @zhengcanbin, I've added more checks to avoid relying on the order and 
non-duplication of received events.
   @tillrohrmann, I've also added more test cases verifying the pending worker 
counter with out-of-ordered and duplicated events.


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


With regards,
Apache Git Servi

[GitHub] [flink] zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] Throw fatal error in KubernetesResourceManager when the pods watcher is closed with exception

2020-04-19 Thread GitBox
zhengcanbin commented on a change in pull request #11010: [FLINK-15836][k8s] 
Throw fatal error in KubernetesResourceManager when the pods watcher is closed 
with exception
URL: https://github.com/apache/flink/pull/11010#discussion_r410837172
 
 

 ##
 File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/kubeclient/resources/KubernetesPodsWatcher.java
 ##
 @@ -0,0 +1,79 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.flink.kubernetes.kubeclient.resources;
+
+import org.apache.flink.kubernetes.kubeclient.FlinkKubeClient;
+
+import io.fabric8.kubernetes.api.model.Pod;
+import io.fabric8.kubernetes.client.KubernetesClientException;
+import io.fabric8.kubernetes.client.Watcher;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import java.util.Collections;
+import java.util.function.Consumer;
+
+/**
+ * Represent Watcher resource for Pods in kubernetes.
+ */
+public class KubernetesPodsWatcher implements Watcher {
+
+   private static final Logger LOG = 
LoggerFactory.getLogger(KubernetesPodsWatcher.class);
+
+   private final FlinkKubeClient.PodCallbackHandler podsCallbackHandler;
+   private final Consumer podsWatcherCloseHandler;
+
+   public KubernetesPodsWatcher(
+   FlinkKubeClient.PodCallbackHandler callbackHandler,
+   Consumer podsWatcherCloseHandler) {
+   this.podsCallbackHandler = callbackHandler;
+   this.podsWatcherCloseHandler = podsWatcherCloseHandler;
+   }
+
+   @Override
+   public void eventReceived(Action action, Pod pod) {
+   LOG.debug("Received {} event for pod {}, details: {}", action, 
pod.getMetadata().getName(), pod.getStatus());
+   switch (action) {
+   case ADDED:
+   
podsCallbackHandler.onAdded(Collections.singletonList(new KubernetesPod(pod)));
+   break;
+   case MODIFIED:
+   
podsCallbackHandler.onModified(Collections.singletonList(new 
KubernetesPod(pod)));
+   break;
+   case ERROR:
+   
podsCallbackHandler.onError(Collections.singletonList(new KubernetesPod(pod)));
+   break;
+   case DELETED:
+   
podsCallbackHandler.onDeleted(Collections.singletonList(new 
KubernetesPod(pod)));
+   break;
+   default:
+   LOG.debug("Ignore handling {} event for pod 
{}", action, pod.getMetadata().getName());
+   break;
+   }
+   }
+
+   @Override
+   public void onClose(KubernetesClientException cause) {
+   LOG.debug("The pods watcher is closing with exception {}.", 
cause == null ? "null" : cause);
 
 Review comment:
   If the `cause` equals to `null`, we'd better log in `INFO` level, otherwise, 
log a `WARNING` message instead.


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11807: [FLINK-16113][table-planner-blink] ExpressionReducer shouldn't escape…

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11807: [FLINK-16113][table-planner-blink] 
ExpressionReducer shouldn't escape…
URL: https://github.com/apache/flink/pull/11807#issuecomment-616061874
 
 
   
   ## CI report:
   
   * 3a7f515b35e2a2ffba69fe45438b67c96c16525c Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160885139) 
   
   
   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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17234) Show more error messages in taskmanager's log

2020-04-19 Thread godfrey he (Jira)


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

godfrey he commented on FLINK-17234:


duplicate with https://issues.apache.org/jira/browse/FLINK-17197

> Show more error messages in taskmanager's log
> -
>
> Key: FLINK-17234
> URL: https://issues.apache.org/jira/browse/FLINK-17234
> Project: Flink
>  Issue Type: Improvement
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), 
> Runtime / Task
>Reporter: Kurt Young
>Priority: Blocker
> Fix For: 1.11.0
>
>
> I created a csv table in sql client and trying to view the table content by 
> executing a simple SELECT * query. 
> First I got the error message printed in sql cli:
> {code:java}
> [ERROR] Could not execute SQL statement. Reason:
> java.lang.IllegalStateException: can't switch state from terminal state 
> READING to CLOSED{code}
> And then I open the TM's log to find more information about what went wrong. 
> The only information I got from log file is similar with sql cli:
> {code:java}
> 2020-04-19 11:50:28,630 WARN  org.apache.flink.runtime.taskmanager.Task       
>              [] - CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.2020-04-19 11:50:28,630 WARN  
> org.apache.flink.runtime.taskmanager.Task                    [] - 
> CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.java.lang.IllegalStateException: can't switch 
> state from terminal state READING to CLOSED at 
> org.apache.flink.util.Preconditions.checkState(Preconditions.java:217) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.switchState(ContinuousFileReaderOperator.java:366)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.lambda$new$0(ContinuousFileReaderOperator.java:213)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.run(StreamTaskActionExecutor.java:42)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:78) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMail(MailboxProcessor.java:276)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxStep(MailboxProcessor.java:205)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:196)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:490)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:718) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.run(Task.java:542) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> java.lang.Thread.run(Thread.java:748) [?:1.8.0_212]{code}
>  
> Finally, it turns out I specified wrong column type of the csv table, and 
> something should have go wrong when reading the data file, but I can't get 
> any useful information from log file. 
> I'm not sure whether the root cause is the error message never thrown by csv 
> parser or got eat up by mailbox model yet. 



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


[jira] [Commented] (FLINK-17226) Remove Prometheus relocations

2020-04-19 Thread Chesnay Schepler (Jira)


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

Chesnay Schepler commented on FLINK-17226:
--

There is a shade-plugin configuration in the pom.xml of the prometheus module. 
We can remove it now.

> Remove Prometheus relocations
> -
>
> Key: FLINK-17226
> URL: https://issues.apache.org/jira/browse/FLINK-17226
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Prometheus reporters as plugins we should remove the 
> shade-plugin configuration/relocations.



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


[GitHub] [flink] flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure 
the permission of scripts set correctly before executing the Python tests
URL: https://github.com/apache/flink/pull/11805#issuecomment-616030530
 
 
   
   ## CI report:
   
   * 2670def9536876df7899cf712e329b0c6f70f692 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160880714) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7720)
 
   * 2a459322ee6445a5743f0d8d06faab05f25a7e66 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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17149) Introduce Debezium format to support reading debezium changelogs

2020-04-19 Thread molsion mo (Jira)


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

molsion mo commented on FLINK-17149:


just introduce, do not need to implement?

> Introduce Debezium format to support reading debezium changelogs
> 
>
> Key: FLINK-17149
> URL: https://issues.apache.org/jira/browse/FLINK-17149
> Project: Flink
>  Issue Type: Sub-task
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), Table 
> SQL / Ecosystem
>Reporter: Jark Wu
>Priority: Major
> Fix For: 1.11.0
>
>
> Introduce {{DebeziumFormatFactory}} and {{DebeziumRowDeserializationSchema}} 
> to read debezium changelogs.
> {code:sql}
> CREATE TABLE my_table (
>   ...
> ) WITH (
>   'connector'='...',  -- e.g. 'kafka'
>   'format'='debezium-json',
>   'format.schema-include'='true' -- default false, Debeizum can be configured 
> to include or exclude the message schema
>   'format.ignore-parse-errors'='true' -- default false
> );
> {code}



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


[GitHub] [flink] flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure 
the permission of scripts set correctly before executing the Python tests
URL: https://github.com/apache/flink/pull/11805#issuecomment-616030530
 
 
   
   ## CI report:
   
   * 2670def9536876df7899cf712e329b0c6f70f692 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160880714) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7720)
 
   * 2a459322ee6445a5743f0d8d06faab05f25a7e66 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160886812) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7723)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce executeSql method in TableEnvironment and support many statements

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce 
executeSql method in TableEnvironment and support many statements
URL: https://github.com/apache/flink/pull/11700#issuecomment-612000686
 
 
   
   ## CI report:
   
   * f52f4a10b99fa573ffeb63f16491d735cc157a4b UNKNOWN
   * 0ac7518a59d0205c3fe65d8bf636f6a8229663bb Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160843171) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7711)
 
   * 1688545ed8f78a69806dc7b27410abd85b70319d 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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11806: [FLINK-17223][AZP] Clean up disk space on Azure-hosted builders

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11806: [FLINK-17223][AZP] Clean up disk 
space on Azure-hosted builders
URL: https://github.com/apache/flink/pull/11806#issuecomment-616051441
 
 
   
   ## CI report:
   
   * 7c034ffcdf78ba9ac64f83c039b30838032da4e4 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160883611) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7722)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16101) Translate "Hive Functions" page of "Hive Integration" into Chinese

2020-04-19 Thread Xu Bai (Jira)


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

Xu Bai commented on FLINK-16101:


Hi,[~jark].

I'm willing to handle this task.Thank you

> Translate "Hive Functions" page of "Hive Integration" into Chinese 
> ---
>
> Key: FLINK-16101
> URL: https://issues.apache.org/jira/browse/FLINK-16101
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/hive/hive_functions.html
> The markdown file is located in 
> {{flink/docs/dev/table/hive/hive_functions.zh.md}}



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


[GitHub] [flink] flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make KubernetesResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make 
KubernetesResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11323#issuecomment-595267888
 
 
   
   ## CI report:
   
   * edd2f98c2a607655aef8823024753fccebe29a7d UNKNOWN
   * 260401deb92878bc2304b23a6988afe812439a7a Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160543406) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7596)
 
   * 7618202f65eaef2a659f52768d3c87ae3b20df9e 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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16093) Translate "System Functions" page of "Functions" into Chinese

2020-04-19 Thread Xu Bai (Jira)


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

Xu Bai commented on FLINK-16093:


Hi,[~jark].

If there's no one else dose this translation, I'm willing to do it.

 

> Translate "System Functions" page of "Functions" into Chinese 
> --
>
> Key: FLINK-16093
> URL: https://issues.apache.org/jira/browse/FLINK-16093
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/functions/systemFunctions.html
> The markdown file is located in 
> {{flink/docs/dev/table/functions/systemFunctions.zh.md}}



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


[GitHub] [flink] flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make KubernetesResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make 
KubernetesResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11323#issuecomment-595267888
 
 
   
   ## CI report:
   
   * edd2f98c2a607655aef8823024753fccebe29a7d UNKNOWN
   * 260401deb92878bc2304b23a6988afe812439a7a Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160543406) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7596)
 
   * 7618202f65eaef2a659f52768d3c87ae3b20df9e Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160887503) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7724)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11807: [FLINK-16113][table-planner-blink] ExpressionReducer shouldn't escape…

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11807: [FLINK-16113][table-planner-blink] 
ExpressionReducer shouldn't escape…
URL: https://github.com/apache/flink/pull/11807#issuecomment-616061874
 
 
   
   ## CI report:
   
   * 3a7f515b35e2a2ffba69fe45438b67c96c16525c Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160885139) 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce executeSql method in TableEnvironment and support many statements

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce 
executeSql method in TableEnvironment and support many statements
URL: https://github.com/apache/flink/pull/11700#issuecomment-612000686
 
 
   
   ## CI report:
   
   * f52f4a10b99fa573ffeb63f16491d735cc157a4b UNKNOWN
   * 0ac7518a59d0205c3fe65d8bf636f6a8229663bb Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160843171) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7711)
 
   * 1688545ed8f78a69806dc7b27410abd85b70319d Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160887539) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7725)
 
   * 15b7686a0b5f781e91c7cc50448f689d08ca38aa 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


With regards,
Apache Git Services


[GitHub] [flink] xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] 
Make YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#discussion_r410851560
 
 

 ##
 File path: 
flink-yarn/src/test/java/org/apache/flink/yarn/YarnResourceManagerTest.java
 ##
 @@ -243,24 +248,33 @@ protected NMClientAsync 
createAndStartNodeManagerClient(YarnConfiguration yarnCo
 
// domain objects for test purposes
final ResourceProfile resourceProfile1 = 
ResourceProfile.UNKNOWN;
+   final WorkerResourceSpec workerResourceSpec;
+
+   final Resource containerResource;
 
public String taskHost = "host1";
 
final TestingYarnNMClientAsync testingYarnNMClientAsync;
 
final TestingYarnAMRMClientAsync testingYarnAMRMClientAsync;
 
+   int containerIdx = 0;
+
/**
 * Create mock RM dependencies.
 */
Context() throws Exception {
-   this(flinkConfig);
+   this(flinkConfig, null);
}
 
-   Context(Configuration configuration) throws  Exception {
-   final SlotManager slotManager = 
SlotManagerBuilder.newBuilder()
-   
.setDefaultWorkerResourceSpec(YarnWorkerResourceSpecFactory.INSTANCE.createDefaultWorkerResourceSpec(configuration))
-   .build();
+   Context(Configuration configuration, @Nullable SlotManager 
slotManager) throws  Exception {
+
+   workerResourceSpec = 
YarnWorkerResourceSpecFactory.INSTANCE.createDefaultWorkerResourceSpec(configuration);
+   if (slotManager == null) {
+   slotManager = SlotManagerBuilder.newBuilder()
+   
.setDefaultWorkerResourceSpec(workerResourceSpec)
+   .build();
+   }
 
 Review comment:
   It requires `workerResourceSpec` for creating the default `slotManager`.
   I was trying to avoid creating `workerResourceSpec` twice, in both 
constructors.


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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17226) Remove Prometheus relocations

2020-04-19 Thread molsion mo (Jira)


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

molsion mo commented on FLINK-17226:


I see what you mean. Will there be other effects after removal?

> Remove Prometheus relocations
> -
>
> Key: FLINK-17226
> URL: https://issues.apache.org/jira/browse/FLINK-17226
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Prometheus reporters as plugins we should remove the 
> shade-plugin configuration/relocations.



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


[GitHub] [flink] gaoyunhaii opened a new pull request #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
gaoyunhaii opened a new pull request #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808
 
 
   ## What is the purpose of the change
   
   This PR translates "Operator/Process Function" page into Chinese.
   
   
   ## Brief change log
   
   This change is a trivial rework / code cleanup without any test coverage.
   
   
   ## 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**
   


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


With regards,
Apache Git Services


[GitHub] [flink] rmetzger merged pull request #11806: [FLINK-17223][AZP] Clean up disk space on Azure-hosted builders

2020-04-19 Thread GitBox
rmetzger merged pull request #11806: [FLINK-17223][AZP] Clean up disk space on 
Azure-hosted builders
URL: https://github.com/apache/flink/pull/11806
 
 
   


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


With regards,
Apache Git Services


[jira] [Resolved] (FLINK-17223) System.IO.IOException: No space left on device in misc profile on free Azure builders

2020-04-19 Thread Robert Metzger (Jira)


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

Robert Metzger resolved FLINK-17223.

Fix Version/s: 1.11.0
   Resolution: Fixed

Resolved in 
https://github.com/apache/flink/commit/cb8ae2892c37dd37431b1b56f96805a3dee0335d

> System.IO.IOException: No space left on device in misc profile on free Azure 
> builders
> -
>
> Key: FLINK-17223
> URL: https://issues.apache.org/jira/browse/FLINK-17223
> Project: Flink
>  Issue Type: Bug
>  Components: Build System / Azure Pipelines
>Affects Versions: 1.11.0
>Reporter: Robert Metzger
>Assignee: Robert Metzger
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>  Time Spent: 20m
>  Remaining Estimate: 0h
>
> Builds on the free Azure builders are failing with
> {code}
> ##[error]Unhandled exception. System.IO.IOException: No space left on device
>at System.IO.FileStream.WriteNative(ReadOnlySpan`1 source)
>at System.IO.FileStream.FlushWriteBuffer()
>at System.IO.FileStream.Flush(Boolean flushToDisk)
>at System.IO.StreamWriter.Flush(Boolean flushStream, Boolean flushEncoder)
>at System.Diagnostics.TextWriterTraceListener.Flush()
>at System.Diagnostics.TraceSource.Flush()
>at Microsoft.VisualStudio.Services.Agent.TraceManager.Dispose(Boolean 
> disposing)
>at Microsoft.VisualStudio.Services.Agent.TraceManager.Dispose()
>at Microsoft.VisualStudio.Services.Agent.HostContext.Dispose(Boolean 
> disposing)
>at Microsoft.VisualStudio.Services.Agent.HostContext.Dispose()
>at Microsoft.VisualStudio.Services.Agent.Worker.Program.Main(String[] args)
> Error reported in diagnostic logs. Please examine the log for more details.
> - /home/vsts/agents/2.165.2/_diag/Worker_20200414-093250-utc.log
> System.IO.IOException: No space left on device
>at System.IO.FileStream.WriteNative(ReadOnlySpan`1 source)
>at System.IO.FileStream.FlushWriteBuffer()
>at System.IO.FileStream.Flush(Boolean flushToDisk)
>at System.IO.StreamWriter.Flush(Boolean flushStream, Boolean flushEncoder)
>at System.Diagnostics.TextWriterTraceListener.Flush()
>at 
> Microsoft.VisualStudio.Services.Agent.HostTraceListener.WriteHeader(String 
> source, TraceEventType eventType, Int32 id)
>at 
> Microsoft.VisualStudio.Services.Agent.HostTraceListener.TraceEvent(TraceEventCache
>  eventCache, String source, TraceEventType eventType, Int32 id, String 
> message)
>at System.Diagnostics.TraceSource.TraceEvent(TraceEventType eventType, 
> Int32 id, String message)
>at Microsoft.VisualStudio.Services.Agent.Worker.Worker.RunAsync(String 
> pipeIn, String pipeOut)
>at 
> Microsoft.VisualStudio.Services.Agent.Worker.Program.MainAsync(IHostContext 
> context, String[] args)
> System.IO.IOException: No space left on device
>at System.IO.FileStream.WriteNative(ReadOnlySpan`1 source)
>at System.IO.FileStream.FlushWriteBuffer()
>at System.IO.FileStream.Flush(Boolean flushToDisk)
>at System.IO.StreamWriter.Flush(Boolean flushStream, Boolean flushEncoder)
>at System.Diagnostics.TextWriterTraceListener.Flush()
>at 
> Microsoft.VisualStudio.Services.Agent.HostTraceListener.WriteHeader(String 
> source, TraceEventType eventType, Int32 id)
>at 
> Microsoft.VisualStudio.Services.Agent.HostTraceListener.TraceEvent(TraceEventCache
>  eventCache, String source, TraceEventType eventType, Int32 id, String 
> message)
>at System.Diagnostics.TraceSource.TraceEvent(TraceEventType eventType, 
> Int32 id, String message)
>at Microsoft.VisualStudio.Services.Agent.Tracing.Error(Exception exception)
>at 
> Microsoft.VisualStudio.Services.Agent.Worker.Program.MainAsync(IHostContext 
> context, String[] args)
> ,##[error]The job running on agent Azure Pipelines 9 ran longer than the 
> maximum time of 240 minutes. For more information, see 
> https://go.microsoft.com/fwlink/?linkid=2077134
> ,##[warning]Agent Azure Pipelines 9 did not respond to a cancelation request 
> with 00:01:00.
> {code}
> CI run: 
> https://dev.azure.com/chesnay/flink/_build/results?buildId=205&view=logs&j=764762df-f65b-572b-3d5c-65518c777be4



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


[jira] [Commented] (FLINK-17220) It reports "No space left on device" on azure pipeline

2020-04-19 Thread Robert Metzger (Jira)


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

Robert Metzger commented on FLINK-17220:


Probably resolved through FLINK-17223

> It reports "No space left on device" on azure pipeline
> --
>
> Key: FLINK-17220
> URL: https://issues.apache.org/jira/browse/FLINK-17220
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dian Fu
>Assignee: Huang Xingbo
>Priority: Major
> Fix For: 1.11.0
>
>
> It failed during preparing the environment when running the Python tests with 
> the following errors: 
> {code}
> Could not install packages due to an EnvironmentError: [Errno 28] No space 
> left on device
> {code}
> instance: 
> https://dev.azure.com/chesnay/0f3463e8-185e-423b-aa88-6cc39182caea/_apis/build/builds/205/logs/116.



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


[GitHub] [flink] flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce executeSql method in TableEnvironment and support many statements

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce 
executeSql method in TableEnvironment and support many statements
URL: https://github.com/apache/flink/pull/11700#issuecomment-612000686
 
 
   
   ## CI report:
   
   * f52f4a10b99fa573ffeb63f16491d735cc157a4b UNKNOWN
   * 1688545ed8f78a69806dc7b27410abd85b70319d Travis: 
[CANCELED](https://travis-ci.com/github/flink-ci/flink/builds/160887539) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7725)
 
   * 15b7686a0b5f781e91c7cc50448f689d08ca38aa 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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17220) It reports "No space left on device" on azure pipeline

2020-04-19 Thread Dian Fu (Jira)


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

Dian Fu commented on FLINK-17220:
-

[~rmetzger] Thanks for working on FLINK-17223. I think so. I will close this 
ticket. We can reopen it if it still happens.

> It reports "No space left on device" on azure pipeline
> --
>
> Key: FLINK-17220
> URL: https://issues.apache.org/jira/browse/FLINK-17220
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dian Fu
>Assignee: Huang Xingbo
>Priority: Major
> Fix For: 1.11.0
>
>
> It failed during preparing the environment when running the Python tests with 
> the following errors: 
> {code}
> Could not install packages due to an EnvironmentError: [Errno 28] No space 
> left on device
> {code}
> instance: 
> https://dev.azure.com/chesnay/0f3463e8-185e-423b-aa88-6cc39182caea/_apis/build/builds/205/logs/116.



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


[GitHub] [flink] flinkbot commented on issue #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
flinkbot commented on issue #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808#issuecomment-616079136
 
 
   Thanks a lot for your contribution to the Apache Flink project. I'm the 
@flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress 
of the review.
   
   
   ## Automated Checks
   Last check on commit 8fc1a7080094527a36fa1f1eb32bf4bd2c548402 (Sun Apr 19 
08:51:38 UTC 2020)
   
✅no warnings
   
   Mention the bot in a comment to re-run the automated checks.
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review 
Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full 
explanation of the review process.
The Bot is tracking the review progress through labels. Labels are applied 
according to the order of the review items. For consensus, approval by a Flink 
committer of PMC member is required Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot approve description` to approve one or more aspects (aspects: 
`description`, `consensus`, `architecture` and `quality`)
- `@flinkbot approve all` to approve all aspects
- `@flinkbot approve-until architecture` to approve everything until 
`architecture`
- `@flinkbot attention @username1 [@username2 ..]` to require somebody's 
attention
- `@flinkbot disapprove architecture` to remove an approval you gave earlier
   


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


With regards,
Apache Git Services


[jira] [Closed] (FLINK-17220) It reports "No space left on device" on azure pipeline

2020-04-19 Thread Dian Fu (Jira)


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

Dian Fu closed FLINK-17220.
---
Resolution: Invalid

> It reports "No space left on device" on azure pipeline
> --
>
> Key: FLINK-17220
> URL: https://issues.apache.org/jira/browse/FLINK-17220
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dian Fu
>Assignee: Huang Xingbo
>Priority: Major
> Fix For: 1.11.0
>
>
> It failed during preparing the environment when running the Python tests with 
> the following errors: 
> {code}
> Could not install packages due to an EnvironmentError: [Errno 28] No space 
> left on device
> {code}
> instance: 
> https://dev.azure.com/chesnay/0f3463e8-185e-423b-aa88-6cc39182caea/_apis/build/builds/205/logs/116.



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


[GitHub] [flink] dianfu closed pull request #11795: [FLINK-17220][python] Clean test environment after finishing test

2020-04-19 Thread GitBox
dianfu closed pull request #11795: [FLINK-17220][python] Clean test environment 
after finishing test
URL: https://github.com/apache/flink/pull/11795
 
 
   


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


With regards,
Apache Git Services


[GitHub] [flink] dianfu commented on issue #11795: [FLINK-17220][python] Clean test environment after finishing test

2020-04-19 Thread GitBox
dianfu commented on issue #11795: [FLINK-17220][python] Clean test environment 
after finishing test
URL: https://github.com/apache/flink/pull/11795#issuecomment-616079661
 
 
   Close this ticket as it should have been fixed in #11806


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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16155) Translate "Operator/Process Function" into Chinese

2020-04-19 Thread Yun Gao (Jira)


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

Yun Gao commented on FLINK-16155:
-

[~xbaith] Hi Bai, very sorry for not open the PR in time, I have nearly 
finished the translation for this and several other opened issues and is 
opening the corresponding PR. Could you help with the translation of some other 
pages ? Otherwise we may have some repeat work. I have first opened this PR and 
any comments are warmly welcomed. :)

> Translate "Operator/Process Function" into Chinese
> --
>
> Key: FLINK-16155
> URL: https://issues.apache.org/jira/browse/FLINK-16155
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Yun Gao
>Assignee: Yun Gao
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>  Time Spent: 0.5h
>  Remaining Estimate: 0h
>
> The page is located at _"docs/dev/stream/operators/process_function.zh.md"_



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


[jira] [Updated] (FLINK-17220) It reports "No space left on device" on azure pipeline

2020-04-19 Thread ASF GitHub Bot (Jira)


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

ASF GitHub Bot updated FLINK-17220:
---
Labels: pull-request-available  (was: )

> It reports "No space left on device" on azure pipeline
> --
>
> Key: FLINK-17220
> URL: https://issues.apache.org/jira/browse/FLINK-17220
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dian Fu
>Assignee: Huang Xingbo
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>
> It failed during preparing the environment when running the Python tests with 
> the following errors: 
> {code}
> Could not install packages due to an EnvironmentError: [Errno 28] No space 
> left on device
> {code}
> instance: 
> https://dev.azure.com/chesnay/0f3463e8-185e-423b-aa88-6cc39182caea/_apis/build/builds/205/logs/116.



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


[GitHub] [flink] dianfu edited a comment on issue #11795: [FLINK-17220][python] Clean test environment after finishing test

2020-04-19 Thread GitBox
dianfu edited a comment on issue #11795: [FLINK-17220][python] Clean test 
environment after finishing test
URL: https://github.com/apache/flink/pull/11795#issuecomment-616079661
 
 
   Close this PR as it should have been fixed in #11806


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
flinkbot commented on issue #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808#issuecomment-616081932
 
 
   
   ## CI report:
   
   * 8fc1a7080094527a36fa1f1eb32bf4bd2c548402 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


With regards,
Apache Git Services


[GitHub] [flink] xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] 
Make YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#discussion_r410858435
 
 

 ##
 File path: 
flink-yarn/src/test/java/org/apache/flink/yarn/RegisterApplicationMasterResponseReflectorTest.java
 ##
 @@ -88,7 +94,44 @@ public void testGetMethodReflectiveHadoop22() {
final RegisterApplicationMasterResponseReflector 
registerApplicationMasterResponseReflector =
new RegisterApplicationMasterResponseReflector(LOG);
 
-   final Method method = 
registerApplicationMasterResponseReflector.getMethod();
+   final Method method = 
registerApplicationMasterResponseReflector.getGetContainersFromPreviousAttemptsMethod();
+   assertThat(method, notNullValue());
+   }
+
+   @Test
+   public void testCallsGetSchedulerResourceTypesMethodIfPresent() {
+   final RegisterApplicationMasterResponseReflector 
registerApplicationMasterResponseReflector =
+   new RegisterApplicationMasterResponseReflector(LOG, 
HasMethod.class);
+
+   final Optional> schedulerResourceTypeNames =
+   
registerApplicationMasterResponseReflector.getSchedulerResourceTypeNamesUnsafe(new
 HasMethod());
 
 Review comment:
   I'm not sure about this. My concern is that, the <2.6 test case might 
eventually not executed in most cases.
   
   Take `testDoesntCallGetContainersFromPreviousAttemptsMethodIfAbsent` as an 
example. If we make this test case only executed with Hadoop <2.2, then it's 
practically not executed. Currently we have Hadoop 2.8 for travis ci test, 2.4 
& 2.8 for nightly test, and 2.4 (pom default) for local maven verify unless 
another version is intentionally specified.


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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16155) Translate "Operator/Process Function" into Chinese

2020-04-19 Thread Bai Xu (Jira)


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

Bai Xu commented on FLINK-16155:


HI,[~gaoyunhaii] .Thanks for your reply.I'm trying to contribute to the Flink 
community.

> Translate "Operator/Process Function" into Chinese
> --
>
> Key: FLINK-16155
> URL: https://issues.apache.org/jira/browse/FLINK-16155
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Yun Gao
>Assignee: Yun Gao
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>  Time Spent: 0.5h
>  Remaining Estimate: 0h
>
> The page is located at _"docs/dev/stream/operators/process_function.zh.md"_



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


[GitHub] [flink] flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808#issuecomment-616081932
 
 
   
   ## CI report:
   
   * 8fc1a7080094527a36fa1f1eb32bf4bd2c548402 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160890194) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7727)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure 
the permission of scripts set correctly before executing the Python tests
URL: https://github.com/apache/flink/pull/11805#issuecomment-616030530
 
 
   
   ## CI report:
   
   * 2a459322ee6445a5743f0d8d06faab05f25a7e66 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160886812) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7723)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16097) Translate "SQL Client" page of "Table API & SQL" into Chinese

2020-04-19 Thread Bai Xu (Jira)


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

Bai Xu commented on FLINK-16097:


Hi,[~jark].I'm willing to translate this page.:D

> Translate "SQL Client" page of "Table API & SQL" into Chinese
> -
>
> Key: FLINK-16097
> URL: https://issues.apache.org/jira/browse/FLINK-16097
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/sqlClient.html
> The markdown file is located in {{flink/docs/dev/table/sqlClient.zh.md}}



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


[jira] [Commented] (FLINK-17234) Show more error messages in taskmanager's log

2020-04-19 Thread Kurt Young (Jira)


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

Kurt Young commented on FLINK-17234:


[~godfreyhe] Thanks

> Show more error messages in taskmanager's log
> -
>
> Key: FLINK-17234
> URL: https://issues.apache.org/jira/browse/FLINK-17234
> Project: Flink
>  Issue Type: Improvement
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), 
> Runtime / Task
>Reporter: Kurt Young
>Priority: Blocker
> Fix For: 1.11.0
>
>
> I created a csv table in sql client and trying to view the table content by 
> executing a simple SELECT * query. 
> First I got the error message printed in sql cli:
> {code:java}
> [ERROR] Could not execute SQL statement. Reason:
> java.lang.IllegalStateException: can't switch state from terminal state 
> READING to CLOSED{code}
> And then I open the TM's log to find more information about what went wrong. 
> The only information I got from log file is similar with sql cli:
> {code:java}
> 2020-04-19 11:50:28,630 WARN  org.apache.flink.runtime.taskmanager.Task       
>              [] - CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.2020-04-19 11:50:28,630 WARN  
> org.apache.flink.runtime.taskmanager.Task                    [] - 
> CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.java.lang.IllegalStateException: can't switch 
> state from terminal state READING to CLOSED at 
> org.apache.flink.util.Preconditions.checkState(Preconditions.java:217) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.switchState(ContinuousFileReaderOperator.java:366)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.lambda$new$0(ContinuousFileReaderOperator.java:213)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.run(StreamTaskActionExecutor.java:42)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:78) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMail(MailboxProcessor.java:276)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxStep(MailboxProcessor.java:205)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:196)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:490)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:718) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.run(Task.java:542) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> java.lang.Thread.run(Thread.java:748) [?:1.8.0_212]{code}
>  
> Finally, it turns out I specified wrong column type of the csv table, and 
> something should have go wrong when reading the data file, but I can't get 
> any useful information from log file. 
> I'm not sure whether the root cause is the error message never thrown by csv 
> parser or got eat up by mailbox model yet. 



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


[jira] [Commented] (FLINK-17226) Remove Prometheus relocations

2020-04-19 Thread molsion mo (Jira)


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

molsion mo commented on FLINK-17226:


I would like to take this task

> Remove Prometheus relocations
> -
>
> Key: FLINK-17226
> URL: https://issues.apache.org/jira/browse/FLINK-17226
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Prometheus reporters as plugins we should remove the 
> shade-plugin configuration/relocations.



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


[jira] [Closed] (FLINK-17234) Show more error messages in taskmanager's log

2020-04-19 Thread Kurt Young (Jira)


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

Kurt Young closed FLINK-17234.
--
Resolution: Duplicate

> Show more error messages in taskmanager's log
> -
>
> Key: FLINK-17234
> URL: https://issues.apache.org/jira/browse/FLINK-17234
> Project: Flink
>  Issue Type: Improvement
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), 
> Runtime / Task
>Reporter: Kurt Young
>Priority: Blocker
> Fix For: 1.11.0
>
>
> I created a csv table in sql client and trying to view the table content by 
> executing a simple SELECT * query. 
> First I got the error message printed in sql cli:
> {code:java}
> [ERROR] Could not execute SQL statement. Reason:
> java.lang.IllegalStateException: can't switch state from terminal state 
> READING to CLOSED{code}
> And then I open the TM's log to find more information about what went wrong. 
> The only information I got from log file is similar with sql cli:
> {code:java}
> 2020-04-19 11:50:28,630 WARN  org.apache.flink.runtime.taskmanager.Task       
>              [] - CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.2020-04-19 11:50:28,630 WARN  
> org.apache.flink.runtime.taskmanager.Task                    [] - 
> CsvTableSource(read fields: t, author) -> 
> SourceConversion(table=[default_catalog.default_database.contri, source: 
> [CsvTableSource(read fields: t, author)]], fields=[t, author]) -> 
> SinkConversionToRow -> Sink: Unnamed (1/1) (ed397f0f69e8f48b320c568f91a5976e) 
> switched from RUNNING to FAILED.java.lang.IllegalStateException: can't switch 
> state from terminal state READING to CLOSED at 
> org.apache.flink.util.Preconditions.checkState(Preconditions.java:217) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.switchState(ContinuousFileReaderOperator.java:366)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator.lambda$new$0(ContinuousFileReaderOperator.java:213)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor$1.run(StreamTaskActionExecutor.java:42)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.Mail.run(Mail.java:78) 
> ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.processMail(MailboxProcessor.java:276)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxStep(MailboxProcessor.java:205)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:196)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:490)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:470)
>  ~[flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:718) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> org.apache.flink.runtime.taskmanager.Task.run(Task.java:542) 
> [flink-dist_2.11-1.11-SNAPSHOT.jar:1.11-SNAPSHOT] at 
> java.lang.Thread.run(Thread.java:748) [?:1.8.0_212]{code}
>  
> Finally, it turns out I specified wrong column type of the csv table, and 
> something should have go wrong when reading the data file, but I can't get 
> any useful information from log file. 
> I'm not sure whether the root cause is the error message never thrown by csv 
> parser or got eat up by mailbox model yet. 



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


[jira] [Commented] (FLINK-17227) Remove Datadog relocations

2020-04-19 Thread molsion mo (Jira)


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

molsion mo commented on FLINK-17227:


I know what it mean. I would like to take this task

> Remove Datadog relocations
> --
>
> Key: FLINK-17227
> URL: https://issues.apache.org/jira/browse/FLINK-17227
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Datadog reporter as a plugin we should remove the 
> shade-plugin configuration/relocations.



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


[GitHub] [flink] HuangXingBo opened a new pull request #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
HuangXingBo opened a new pull request #11809: [FLINK-17118][python] Add Cython 
support for primitive data types
URL: https://github.com/apache/flink/pull/11809
 
 
   ## What is the purpose of the change
   
   *This pull request will support primitive DataTypes in Cython*
   
   
   ## Brief change log
 - *Use rmetzger/flink-ci:ubuntu-amd64-bcef226 image which contains gcc 
used for PyFlink cython tests*
 - *Adds the file fast_coder_impl.(pyx,pxd) which includes the 
implementation of cython*
 - *Add cython test environment in tox*
   
   ## Verifying this change
 - *Add correponding unit test in test_coders_common.py*
 - *Add cython test environment in tox*
   
   ## 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)
   


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
flinkbot commented on issue #11809: [FLINK-17118][python] Add Cython support 
for primitive data types
URL: https://github.com/apache/flink/pull/11809#issuecomment-616088261
 
 
   Thanks a lot for your contribution to the Apache Flink project. I'm the 
@flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress 
of the review.
   
   
   ## Automated Checks
   Last check on commit ce14ff9be8664c8d5bad912e8fbfa3881e0cc339 (Sun Apr 19 
09:41:34 UTC 2020)
   
   **Warnings:**
* No documentation files were touched! Remember to keep the Flink docs up 
to date!
   
   
   Mention the bot in a comment to re-run the automated checks.
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review 
Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full 
explanation of the review process.
The Bot is tracking the review progress through labels. Labels are applied 
according to the order of the review items. For consensus, approval by a Flink 
committer of PMC member is required Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot approve description` to approve one or more aspects (aspects: 
`description`, `consensus`, `architecture` and `quality`)
- `@flinkbot approve all` to approve all aspects
- `@flinkbot approve-until architecture` to approve everything until 
`architecture`
- `@flinkbot attention @username1 [@username2 ..]` to require somebody's 
attention
- `@flinkbot disapprove architecture` to remove an approval you gave earlier
   


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make KubernetesResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make 
KubernetesResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11323#issuecomment-595267888
 
 
   
   ## CI report:
   
   * edd2f98c2a607655aef8823024753fccebe29a7d UNKNOWN
   * 7618202f65eaef2a659f52768d3c87ae3b20df9e Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160887503) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7724)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
xintongsong commented on a change in pull request #11353: [FLINK-16438][yarn] 
Make YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#discussion_r410865789
 
 

 ##
 File path: 
flink-yarn/src/test/java/org/apache/flink/yarn/TestingYarnAMRMClientAsync.java
 ##
 @@ -0,0 +1,158 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.flink.yarn;
+
+import org.apache.flink.api.java.tuple.Tuple4;
+import org.apache.flink.util.Preconditions;
+import org.apache.flink.util.function.TriConsumer;
+import org.apache.flink.util.function.TriFunction;
+
+import org.apache.hadoop.conf.Configuration;
+import 
org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterResponse;
+import org.apache.hadoop.yarn.api.records.ContainerId;
+import org.apache.hadoop.yarn.api.records.FinalApplicationStatus;
+import org.apache.hadoop.yarn.api.records.Priority;
+import org.apache.hadoop.yarn.api.records.Resource;
+import org.apache.hadoop.yarn.client.api.AMRMClient;
+import org.apache.hadoop.yarn.client.api.async.AMRMClientAsync;
+import org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl;
+
+import java.util.Collection;
+import java.util.Collections;
+import java.util.List;
+import java.util.function.BiConsumer;
+import java.util.function.Consumer;
+import java.util.function.Function;
+
+/**
+ * A Yarn {@link AMRMClientAsync} implementation for testing.
+ */
+public class TestingYarnAMRMClientAsync extends 
AMRMClientAsyncImpl {
+
+   private Function, 
List>>
+   getMatchingRequestsFunction = ignored -> 
Collections.emptyList();
+   private BiConsumer 
addContainerRequestConsumer = (ignored1, ignored2) -> {};
+   private BiConsumer 
removeContainerRequestConsumer = (ignored1, ignored2) -> {};
+   private BiConsumer 
releaseAssignedContainerConsumer = (ignored1, ignored2) -> {};
+   private Consumer setHeartbeatIntervalConsumer = (ignored) -> 
{};
+   private TriFunction registerApplicationMasterFunction =
+   (ignored1, ignored2, ignored3) -> 
RegisterApplicationMasterResponse.newInstance(
+   Resource.newInstance(0, 0),
+   Resource.newInstance(Integer.MAX_VALUE, 
Integer.MAX_VALUE),
+   Collections.emptyMap(),
+   null,
+   Collections.emptyList(),
+   null,
+   Collections.emptyList());
+   private TriConsumer 
unregisterApplicationMasterConsumer = (ignored1, ignored2, ignored3) -> {};
+
+   TestingYarnAMRMClientAsync(CallbackHandler callbackHandler) {
+   super(0, callbackHandler);
+   }
+
+   @Override
+   public List> 
getMatchingRequests(Priority priority, String resourceName, Resource 
capability) {
+   return getMatchingRequestsFunction.apply(Tuple4.of(priority, 
resourceName, capability, handler));
+   }
+
+   @Override
+   public void addContainerRequest(AMRMClient.ContainerRequest req) {
+   addContainerRequestConsumer.accept(req, handler);
+   }
+
+   @Override
+   public void removeContainerRequest(AMRMClient.ContainerRequest req) {
+   removeContainerRequestConsumer.accept(req, handler);
+   }
+
+   @Override
+   public void releaseAssignedContainer(ContainerId containerId) {
+   releaseAssignedContainerConsumer.accept(containerId, handler);
+   }
+
+   @Override
+   public void setHeartbeatInterval(int interval) {
+   setHeartbeatIntervalConsumer.accept(interval);
+   }
+
+   @Override
+   public RegisterApplicationMasterResponse 
registerApplicationMaster(String appHostName, int appHostPort, String 
appTrackingUrl) {
+   return registerApplicationMasterFunction.apply(appHostName, 
appHostPort, appTrackingUrl);
+   }
+
+   @Override
+   public void unregisterApplicationMaster(FinalApplicationStatus 
appStatus, String appMessage, String appTrackingUrl) {
+   unregisterApplicationMasterConsumer.accept(appStatus, 
appMessage, appTrackingUrl);
+   }
+

[GitHub] [flink] flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make KubernetesResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11323: [FLINK-16439][k8s] Make 
KubernetesResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11323#issuecomment-595267888
 
 
   
   ## CI report:
   
   * edd2f98c2a607655aef8823024753fccebe29a7d UNKNOWN
   * 7618202f65eaef2a659f52768d3c87ae3b20df9e Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160887503) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7724)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make 
YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#issuecomment-596455079
 
 
   
   ## CI report:
   
   * 220c5fac2e7eefb4776f0909ebce640186301309 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160002973) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7375)
 
   * c4edf089b07a5a95a8cc53c6a32bd98ff3f7dde0 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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808#issuecomment-616081932
 
 
   
   ## CI report:
   
   * 8fc1a7080094527a36fa1f1eb32bf4bd2c548402 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160890194) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7727)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
flinkbot commented on issue #11809: [FLINK-17118][python] Add Cython support 
for primitive data types
URL: https://github.com/apache/flink/pull/11809#issuecomment-616094062
 
 
   
   ## CI report:
   
   * ce14ff9be8664c8d5bad912e8fbfa3881e0cc339 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


With regards,
Apache Git Services


[GitHub] [flink] Xeli opened a new pull request #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
Xeli opened a new pull request #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810
 
 
   I was unable to consistently reproduce the failing test (see jira ticket for 
logs). This MR fixes a bug where it would try to send an acknowledge request 
without any acknowledge id. After that fix, I did not see the test failing 
anymore.
   
   I do not think this should fix it entirely but I cannot see it failing 
anymore. I'd like to add this fix and see if the problem arises again and if so 
with what kind of exceptions.


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


With regards,
Apache Git Services


[jira] [Updated] (FLINK-16572) CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread ASF GitHub Bot (Jira)


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

ASF GitHub Bot updated FLINK-16572:
---
Labels: pull-request-available test-stability  (was: test-stability)

> CheckPubSubEmulatorTest is flaky on Azure
> -
>
> Key: FLINK-16572
> URL: https://issues.apache.org/jira/browse/FLINK-16572
> Project: Flink
>  Issue Type: Bug
>  Components: Build System / Azure Pipelines, Connectors / Google 
> Cloud PubSub
>Affects Versions: 1.11.0
>Reporter: Aljoscha Krettek
>Assignee: Richard Deurwaarder
>Priority: Critical
>  Labels: pull-request-available, test-stability
> Fix For: 1.11.0
>
>
> Log: 
> https://dev.azure.com/aljoschakrettek/Flink/_build/results?buildId=56&view=logs&j=1f3ed471-1849-5d3c-a34c-19792af4ad16&t=ce095137-3e3b-5f73-4b79-c42d3d5f8283&l=7842



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


[GitHub] [flink] flinkbot commented on issue #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
flinkbot commented on issue #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810#issuecomment-616095394
 
 
   Thanks a lot for your contribution to the Apache Flink project. I'm the 
@flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress 
of the review.
   
   
   ## Automated Checks
   Last check on commit 8e8584c51dcb2bfd4967c4299550b01f32b013ee (Sun Apr 19 
10:15:52 UTC 2020)
   
   **Warnings:**
* No documentation files were touched! Remember to keep the Flink docs up 
to date!
   
   
   Mention the bot in a comment to re-run the automated checks.
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review 
Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full 
explanation of the review process.
The Bot is tracking the review progress through labels. Labels are applied 
according to the order of the review items. For consensus, approval by a Flink 
committer of PMC member is required Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot approve description` to approve one or more aspects (aspects: 
`description`, `consensus`, `architecture` and `quality`)
- `@flinkbot approve all` to approve all aspects
- `@flinkbot approve-until architecture` to approve everything until 
`architecture`
- `@flinkbot attention @username1 [@username2 ..]` to require somebody's 
attention
- `@flinkbot disapprove architecture` to remove an approval you gave earlier
   


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


With regards,
Apache Git Services


[GitHub] [flink-statefun] authuir opened a new pull request #100: [FLINK-17060][docs] Replace "{flink}" with the Apache Flink trademark

2020-04-19 Thread GitBox
authuir opened a new pull request #100: [FLINK-17060][docs] Replace "{flink}" 
with the Apache Flink trademark
URL: https://github.com/apache/flink-statefun/pull/100
 
 
   Replace "{flink}" with the Apache Flink trademark


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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17060) "{flink}" isn't being replaced by the Apache Flink trademark in Stateful Functions docs

2020-04-19 Thread Authuir (Jira)


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

Authuir commented on FLINK-17060:
-

PR created: [https://github.com/apache/flink-statefun/pull/100]

> "{flink}" isn't being replaced by the Apache Flink trademark in Stateful 
> Functions docs
> ---
>
> Key: FLINK-17060
> URL: https://issues.apache.org/jira/browse/FLINK-17060
> Project: Flink
>  Issue Type: Bug
>  Components: Documentation, Stateful Functions
>Affects Versions: statefun-2.0.0
>Reporter: Tzu-Li (Gordon) Tai
>Priority: Major
>  Labels: pull-request-available
> Fix For: statefun-2.0.1, statefun-2.1.0
>
>  Time Spent: 10m
>  Remaining Estimate: 0h
>
> See 
> https://ci.apache.org/projects/flink/flink-statefun-docs-master/sdk/modules.html#embedded-module



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


[GitHub] [flink] flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make 
YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#issuecomment-596455079
 
 
   
   ## CI report:
   
   * 220c5fac2e7eefb4776f0909ebce640186301309 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160002973) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7375)
 
   * c4edf089b07a5a95a8cc53c6a32bd98ff3f7dde0 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160893255) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7728)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Updated] (FLINK-17060) "{flink}" isn't being replaced by the Apache Flink trademark in Stateful Functions docs

2020-04-19 Thread ASF GitHub Bot (Jira)


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

ASF GitHub Bot updated FLINK-17060:
---
Labels: pull-request-available  (was: )

> "{flink}" isn't being replaced by the Apache Flink trademark in Stateful 
> Functions docs
> ---
>
> Key: FLINK-17060
> URL: https://issues.apache.org/jira/browse/FLINK-17060
> Project: Flink
>  Issue Type: Bug
>  Components: Documentation, Stateful Functions
>Affects Versions: statefun-2.0.0
>Reporter: Tzu-Li (Gordon) Tai
>Priority: Major
>  Labels: pull-request-available
> Fix For: statefun-2.0.1, statefun-2.1.0
>
>
> See 
> https://ci.apache.org/projects/flink/flink-statefun-docs-master/sdk/modules.html#embedded-module



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


[GitHub] [flink] flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython 
support for primitive data types
URL: https://github.com/apache/flink/pull/11809#issuecomment-616094062
 
 
   
   ## CI report:
   
   * ce14ff9be8664c8d5bad912e8fbfa3881e0cc339 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160893292) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7729)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
flinkbot commented on issue #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810#issuecomment-616097140
 
 
   
   ## CI report:
   
   * 8e8584c51dcb2bfd4967c4299550b01f32b013ee 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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate "Operator/Process Function" page into Chinese

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11808: [FLINK-16155][docs-zh] Translate 
"Operator/Process Function" page into Chinese
URL: https://github.com/apache/flink/pull/11808#issuecomment-616081932
 
 
   
   ## CI report:
   
   * 8fc1a7080094527a36fa1f1eb32bf4bd2c548402 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160890194) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7727)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810#issuecomment-616097140
 
 
   
   ## CI report:
   
   * 8e8584c51dcb2bfd4967c4299550b01f32b013ee Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160894187) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7730)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11805: [FLINK-17068][python][tests] Ensure 
the permission of scripts set correctly before executing the Python tests
URL: https://github.com/apache/flink/pull/11805#issuecomment-616030530
 
 
   
   ## CI report:
   
   * 2a459322ee6445a5743f0d8d06faab05f25a7e66 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160886812) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7723)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] aljoscha opened a new pull request #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
aljoscha opened a new pull request #11811: [FLINK-16658][FLINK-16660] Introduce 
the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811
 
 
   For triggering CI for #11696 because Flinkbot does not seem to listen to 
commands there anymore.


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
flinkbot commented on issue #11811: [FLINK-16658][FLINK-16660] Introduce the 
ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811#issuecomment-616104816
 
 
   Thanks a lot for your contribution to the Apache Flink project. I'm the 
@flinkbot. I help the community
   to review your pull request. We will use this comment to track the progress 
of the review.
   
   
   ## Automated Checks
   Last check on commit 40bd2693a11d52097fd55b23173710f35965dcb7 (Sun Apr 19 
11:04:17 UTC 2020)
   
   **Warnings:**
* No documentation files were touched! Remember to keep the Flink docs up 
to date!
   
   
   Mention the bot in a comment to re-run the automated checks.
   ## Review Progress
   
   * ❓ 1. The [description] looks good.
   * ❓ 2. There is [consensus] that the contribution should go into to Flink.
   * ❓ 3. Needs [attention] from.
   * ❓ 4. The change fits into the overall [architecture].
   * ❓ 5. Overall code [quality] is good.
   
   Please see the [Pull Request Review 
Guide](https://flink.apache.org/contributing/reviewing-prs.html) for a full 
explanation of the review process.
The Bot is tracking the review progress through labels. Labels are applied 
according to the order of the review items. For consensus, approval by a Flink 
committer of PMC member is required Bot commands
 The @flinkbot bot supports the following commands:
   
- `@flinkbot approve description` to approve one or more aspects (aspects: 
`description`, `consensus`, `architecture` and `quality`)
- `@flinkbot approve all` to approve all aspects
- `@flinkbot approve-until architecture` to approve everything until 
`architecture`
- `@flinkbot attention @username1 [@username2 ..]` to require somebody's 
attention
- `@flinkbot disapprove architecture` to remove an approval you gave earlier
   


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


With regards,
Apache Git Services


[GitHub] [flink] dianfu merged pull request #11805: [FLINK-17068][python][tests] Ensure the permission of scripts set correctly before executing the Python tests

2020-04-19 Thread GitBox
dianfu merged pull request #11805: [FLINK-17068][python][tests] Ensure the 
permission of scripts set correctly before executing the Python tests
URL: https://github.com/apache/flink/pull/11805
 
 
   


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


With regards,
Apache Git Services


[jira] [Closed] (FLINK-17068) ERROR at teardown of TableConfigTests.test_get_set_decimal_context

2020-04-19 Thread Dian Fu (Jira)


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

Dian Fu closed FLINK-17068.
---
Resolution: Fixed

Merged to master via 6e613398ef5bb9654fe8595fb9ff09c062389bb4

> ERROR at teardown of TableConfigTests.test_get_set_decimal_context
> --
>
> Key: FLINK-17068
> URL: https://issues.apache.org/jira/browse/FLINK-17068
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Tests
>Affects Versions: 1.11.0
>Reporter: Robert Metzger
>Assignee: Dian Fu
>Priority: Critical
>  Labels: pull-request-available, test-stability
> Fix For: 1.11.0
>
>  Time Spent: 20m
>  Remaining Estimate: 0h
>
> CI run: 
> https://dev.azure.com/rmetzger/Flink/_build/results?buildId=7243&view=logs&j=9cada3cb-c1d3-5621-16da-0f718fb86602&t=14487301-07d2-5d56-5690-6dfab9ffd4d9
> {code}
> 2020-04-09T00:34:15.9084299Z  ERRORS 
> 
> 2020-04-09T00:34:15.9085728Z __ ERROR at teardown of 
> TableConfigTests.test_get_set_decimal_context __
> 2020-04-09T00:34:15.9086216Z 
> 2020-04-09T00:34:15.9086725Z self =  object at 0x7f8d978989b0>
> 2020-04-09T00:34:15.9087144Z 
> 2020-04-09T00:34:15.9087457Z def __enter__(self):
> 2020-04-09T00:34:15.9087787Z try:
> 2020-04-09T00:34:15.9091929Z >   return next(self.gen)
> 2020-04-09T00:34:15.9092634Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9092863Z 
> 2020-04-09T00:34:15.9093134Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9093548Z __ ERROR at setup of 
> TableConfigTests.test_get_set_idle_state_retention_time ___
> 2020-04-09T00:34:15.9093803Z 
> 2020-04-09T00:34:15.9094082Z self =  object at 0x7f8d9c3f3da0>
> 2020-04-09T00:34:15.9094313Z 
> 2020-04-09T00:34:15.9094502Z def __enter__(self):
> 2020-04-09T00:34:15.9094862Z try:
> 2020-04-09T00:34:15.9095088Z >   return next(self.gen)
> 2020-04-09T00:34:15.9095707Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9095913Z 
> 2020-04-09T00:34:15.9096203Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9096818Z _ ERROR at teardown of 
> TableConfigTests.test_get_set_idle_state_retention_time _
> 2020-04-09T00:34:15.9100686Z 
> 2020-04-09T00:34:15.9101687Z self =  object at 0x7f8d978d83c8>
> 2020-04-09T00:34:15.9102005Z 
> 2020-04-09T00:34:15.9102193Z def __enter__(self):
> 2020-04-09T00:34:15.9102415Z try:
> 2020-04-09T00:34:15.9102741Z >   return next(self.gen)
> 2020-04-09T00:34:15.9103144Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9103367Z 
> 2020-04-09T00:34:15.9103786Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9104185Z  ERROR at setup of 
> TableConfigTests.test_get_set_local_timezone 
> 2020-04-09T00:34:15.9104999Z 
> 2020-04-09T00:34:15.9105287Z self =  object at 0x7f8d979345f8>
> 2020-04-09T00:34:15.9105531Z 
> 2020-04-09T00:34:15.9105707Z def __enter__(self):
> 2020-04-09T00:34:15.9105924Z try:
> 2020-04-09T00:34:15.9106138Z >   return next(self.gen)
> 2020-04-09T00:34:15.9106555Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9106858Z 
> 2020-04-09T00:34:15.9107159Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9107675Z __ ERROR at teardown of 
> TableConfigTests.test_get_set_local_timezone ___
> 2020-04-09T00:34:15.9107983Z 
> 2020-04-09T00:34:15.9108350Z self =  object at 0x7f8d981f8240>
> 2020-04-09T00:34:15.9108699Z 
> 2020-04-09T00:34:15.9108983Z def __enter__(self):
> 2020-04-09T00:34:15.9109311Z try:
> 2020-04-09T00:34:15.9109566Z >   return next(self.gen)
> 2020-04-09T00:34:15.9109872Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9110082Z 
> 2020-04-09T00:34:15.9110349Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9111098Z __ ERROR at setup of 
> TableConfigTests.test_get_set_max_generated_code_length ___
> 2020-04-09T00:34:15.9111479Z 
> 2020-04-09T00:34:15.9111740Z self =  object at 0x7f8d9c3380f0>
> 2020-04-09T00:34:15.9112010Z 
> 2020-04-09T00:34:15.9112297Z def __enter__(self):
> 2020-04-09T00:34:15.9112571Z try:
> 2020-04-09T00:34:15.9112803Z >   return next(self.gen)
> 2020-04-09T00:34:15.9113114Z E   OSError: [Errno 9] Bad file 
> descriptor
> 2020-04-09T00:34:15.9113353Z 
> 2020-04-09T00:34:15.9113737Z 
> dev/.conda/envs/3.5/lib/python3.5/contextlib.py:59: OSError
> 2020-04-09T00:34:15.9114282Z _ ERROR at teardown of 
> TableConfigTests.test_get_set_max

[GitHub] [flink] flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce executeSql method in TableEnvironment and support many statements

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11700: [FLINK-16366] [table] Introduce 
executeSql method in TableEnvironment and support many statements
URL: https://github.com/apache/flink/pull/11700#issuecomment-612000686
 
 
   
   ## CI report:
   
   * f52f4a10b99fa573ffeb63f16491d735cc157a4b UNKNOWN
   * 1688545ed8f78a69806dc7b27410abd85b70319d Travis: 
[CANCELED](https://travis-ci.com/github/flink-ci/flink/builds/160887539) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7725)
 
   * 15b7686a0b5f781e91c7cc50448f689d08ca38aa 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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot commented on issue #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
flinkbot commented on issue #11811: [FLINK-16658][FLINK-16660] Introduce the 
ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811#issuecomment-616107576
 
 
   
   ## CI report:
   
   * 40bd2693a11d52097fd55b23173710f35965dcb7 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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17149) Introduce Debezium format to support reading debezium changelogs

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-17149:
-

Hi [~molsion], the "introduce" I mean is an implementation, not a 
documentation. 

> Introduce Debezium format to support reading debezium changelogs
> 
>
> Key: FLINK-17149
> URL: https://issues.apache.org/jira/browse/FLINK-17149
> Project: Flink
>  Issue Type: Sub-task
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), Table 
> SQL / Ecosystem
>Reporter: Jark Wu
>Priority: Major
> Fix For: 1.11.0
>
>
> Introduce {{DebeziumFormatFactory}} and {{DebeziumRowDeserializationSchema}} 
> to read debezium changelogs.
> {code:sql}
> CREATE TABLE my_table (
>   ...
> ) WITH (
>   'connector'='...',  -- e.g. 'kafka'
>   'format'='debezium-json',
>   'format.schema-include'='true' -- default false, Debeizum can be configured 
> to include or exclude the message schema
>   'format.ignore-parse-errors'='true' -- default false
> );
> {code}



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


[jira] [Commented] (FLINK-16093) Translate "System Functions" page of "Functions" into Chinese

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-16093:
-

Hi [~xbaith], there will be some refactoring for this page. So I would suggest 
to translate other pages first. Thanks.

> Translate "System Functions" page of "Functions" into Chinese 
> --
>
> Key: FLINK-16093
> URL: https://issues.apache.org/jira/browse/FLINK-16093
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/functions/systemFunctions.html
> The markdown file is located in 
> {{flink/docs/dev/table/functions/systemFunctions.zh.md}}



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


[jira] [Commented] (FLINK-16101) Translate "Hive Functions" page of "Hive Integration" into Chinese

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-16101:
-

Hi [~xbaith], there is already a PR under reviewing. Are you the author 
"zzh1985"? 

> Translate "Hive Functions" page of "Hive Integration" into Chinese 
> ---
>
> Key: FLINK-16101
> URL: https://issues.apache.org/jira/browse/FLINK-16101
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/hive/hive_functions.html
> The markdown file is located in 
> {{flink/docs/dev/table/hive/hive_functions.zh.md}}



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


[GitHub] [flink] flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make 
YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#issuecomment-596455079
 
 
   
   ## CI report:
   
   * c4edf089b07a5a95a8cc53c6a32bd98ff3f7dde0 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160893255) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7728)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] wuchong merged pull request #11807: [FLINK-16113][table-planner-blink] ExpressionReducer shouldn't escape…

2020-04-19 Thread GitBox
wuchong merged pull request #11807: [FLINK-16113][table-planner-blink] 
ExpressionReducer shouldn't escape…
URL: https://github.com/apache/flink/pull/11807
 
 
   


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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce 
the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811#issuecomment-616107576
 
 
   
   ## CI report:
   
   * 40bd2693a11d52097fd55b23173710f35965dcb7 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160897124) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7732)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Updated] (FLINK-16113) ExpressionReducer shouldn't escape the reduced string value

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu updated FLINK-16113:

Fix Version/s: 1.9.4

> ExpressionReducer shouldn't escape the reduced string value
> ---
>
> Key: FLINK-16113
> URL: https://issues.apache.org/jira/browse/FLINK-16113
> Project: Flink
>  Issue Type: Bug
>  Components: Table SQL / Planner
>Affects Versions: 1.10.0
>Reporter: Jark Wu
>Assignee: Jark Wu
>Priority: Critical
>  Labels: pull-request-available
> Fix For: 1.10.1, 1.11.0, 1.9.4
>
>  Time Spent: 40m
>  Remaining Estimate: 0h
>
> ExpressionReducer shouldn't escape the reduced string value, the escaping 
> should only happen in code generation, otherwise the output result is 
> inccorect. 
> The problem is this line I guess: 
> https://github.com/apache/flink/blob/master/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/planner/codegen/ExpressionReducer.scala#L142
> Here is a simple example to reproduce the problem:
> {code:java}
>   val smallTupleData3: Seq[(Int, Long, String)] = {
> val data = new mutable.MutableList[(Int, Long, String)]
> data.+=((1, 1L, "你好"))
> data.+=((2, 2L, "你好"))
> data.+=((3, 2L, "你好世界"))
> data
>   }
>   @Test
>   def test(): Unit = {
> val t = env.fromCollection(smallTupleData3)
>   .toTable(tEnv, 'a, 'b, 'c)
> tEnv.createTemporaryView("MyTable", t)
> val sqlQuery = s"select * from MyTable where c = '你好'"
> val result = tEnv.sqlQuery(sqlQuery).toAppendStream[Row]
> val sink = new TestingAppendSink
> result.addSink(sink)
> env.execute()
> println(sink.getAppendResults.mkString("\n"))
>   }
> {code}
> The output:
> {code:java}
> 1,1,\u4F60\u597D
> 2,2,\u4F60\u597D
> {code}
> This is also mentioned in user mailing list: 
> http://apache-flink.147419.n8.nabble.com/ParquetTableSource-blink-table-planner-tp1696p1720.html



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


[jira] [Commented] (FLINK-16113) ExpressionReducer shouldn't escape the reduced string value

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-16113:
-

Fixed in 1.9.4: 0fdb8079394055cffabf5060130751250e35b620

> ExpressionReducer shouldn't escape the reduced string value
> ---
>
> Key: FLINK-16113
> URL: https://issues.apache.org/jira/browse/FLINK-16113
> Project: Flink
>  Issue Type: Bug
>  Components: Table SQL / Planner
>Affects Versions: 1.10.0
>Reporter: Jark Wu
>Assignee: Jark Wu
>Priority: Critical
>  Labels: pull-request-available
> Fix For: 1.10.1, 1.11.0, 1.9.4
>
>  Time Spent: 40m
>  Remaining Estimate: 0h
>
> ExpressionReducer shouldn't escape the reduced string value, the escaping 
> should only happen in code generation, otherwise the output result is 
> inccorect. 
> The problem is this line I guess: 
> https://github.com/apache/flink/blob/master/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/planner/codegen/ExpressionReducer.scala#L142
> Here is a simple example to reproduce the problem:
> {code:java}
>   val smallTupleData3: Seq[(Int, Long, String)] = {
> val data = new mutable.MutableList[(Int, Long, String)]
> data.+=((1, 1L, "你好"))
> data.+=((2, 2L, "你好"))
> data.+=((3, 2L, "你好世界"))
> data
>   }
>   @Test
>   def test(): Unit = {
> val t = env.fromCollection(smallTupleData3)
>   .toTable(tEnv, 'a, 'b, 'c)
> tEnv.createTemporaryView("MyTable", t)
> val sqlQuery = s"select * from MyTable where c = '你好'"
> val result = tEnv.sqlQuery(sqlQuery).toAppendStream[Row]
> val sink = new TestingAppendSink
> result.addSink(sink)
> env.execute()
> println(sink.getAppendResults.mkString("\n"))
>   }
> {code}
> The output:
> {code:java}
> 1,1,\u4F60\u597D
> 2,2,\u4F60\u597D
> {code}
> This is also mentioned in user mailing list: 
> http://apache-flink.147419.n8.nabble.com/ParquetTableSource-blink-table-planner-tp1696p1720.html



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


[jira] [Assigned] (FLINK-16097) Translate "SQL Client" page of "Table API & SQL" into Chinese

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu reassigned FLINK-16097:
---

Assignee: Bai Xu

> Translate "SQL Client" page of "Table API & SQL" into Chinese
> -
>
> Key: FLINK-16097
> URL: https://issues.apache.org/jira/browse/FLINK-16097
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Assignee: Bai Xu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/sqlClient.html
> The markdown file is located in {{flink/docs/dev/table/sqlClient.zh.md}}



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


[jira] [Commented] (FLINK-16155) Translate "Operator/Process Function" into Chinese

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-16155:
-

Hi [~xbaith], thanks for the contribution. Reviewing is also a great 
contribution to the community, and can push forward things faster. If you have 
time, you can help review this PR :)

> Translate "Operator/Process Function" into Chinese
> --
>
> Key: FLINK-16155
> URL: https://issues.apache.org/jira/browse/FLINK-16155
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Yun Gao
>Assignee: Yun Gao
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>  Time Spent: 0.5h
>  Remaining Estimate: 0h
>
> The page is located at _"docs/dev/stream/operators/process_function.zh.md"_



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


[jira] [Commented] (FLINK-16097) Translate "SQL Client" page of "Table API & SQL" into Chinese

2020-04-19 Thread Jark Wu (Jira)


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

Jark Wu commented on FLINK-16097:
-

Assigned to you [~xbaith].

> Translate "SQL Client" page of "Table API & SQL" into Chinese
> -
>
> Key: FLINK-16097
> URL: https://issues.apache.org/jira/browse/FLINK-16097
> Project: Flink
>  Issue Type: Sub-task
>  Components: chinese-translation, Documentation
>Reporter: Jark Wu
>Assignee: Bai Xu
>Priority: Major
>
> The page url is 
> https://ci.apache.org/projects/flink/flink-docs-master/zh/dev/table/sqlClient.html
> The markdown file is located in {{flink/docs/dev/table/sqlClient.zh.md}}



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


[GitHub] [flink] flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython 
support for primitive data types
URL: https://github.com/apache/flink/pull/11809#issuecomment-616094062
 
 
   
   ## CI report:
   
   * ce14ff9be8664c8d5bad912e8fbfa3881e0cc339 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160893292) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7729)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] KurtYoung closed pull request #11700: [FLINK-16366] [table] Introduce executeSql method in TableEnvironment and support many statements

2020-04-19 Thread GitBox
KurtYoung closed pull request #11700: [FLINK-16366] [table] Introduce 
executeSql method in TableEnvironment and support many statements
URL: https://github.com/apache/flink/pull/11700
 
 
   


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


With regards,
Apache Git Services


[jira] [Closed] (FLINK-16366) Introduce executeSql method in TableEnvironment

2020-04-19 Thread Kurt Young (Jira)


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

Kurt Young closed FLINK-16366.
--
Resolution: Fixed

master: e0d2db7e2015aad73a1eda092a600cf92c78bb43

> Introduce executeSql method in TableEnvironment
> ---
>
> Key: FLINK-16366
> URL: https://issues.apache.org/jira/browse/FLINK-16366
> Project: Flink
>  Issue Type: Sub-task
>  Components: Table SQL / API
>Reporter: godfrey he
>Assignee: godfrey he
>Priority: Major
>  Labels: pull-request-available
> Fix For: 1.11.0
>
>  Time Spent: 20m
>  Remaining Estimate: 0h
>
> This issue aims to introduce {{executeSql}} which can execute the given 
> single statement, and returns the execution result. 
> This method only supports executing a single statement which can be DDL, DML, 
> DQL, SHOW, DESCRIBE, EXPLAIN and USE.  For DML and DQL, this method returns 
> TableResult once the job has been submitted. For DDL and DCL statements, 
> TableResult is returned once the operation has finished.
> {code:java}
> interface TableEnvironment {
>  /**
>   * Execute the given single statement and
>   * the statement can be DDL/DML/DQL/SHOW/DESCRIBE/EXPLAIN/USE.
>   *
>   * If the statement is translated to a Flink job (DML/DQL),
>   * the TableResult will be returned until the job is submitted, and
>   * contains a JobClient instance to associate the job.
>   * Else, the TableResult will be returned until the statement
>   * execution is finished, does not contain a JobClient instance.
>   *
>   * @return result for DQL/SHOW/DESCRIBE/EXPLAIN, the affected row count
>   * for `DML` (-1 means unknown),or a string message ("OK") for other 
>   * statements.
>   */
> TableResult executeSql(String statement);
> }
> /**
>  * A TableResult is the representation of the statement execution result.
>  */
> interface TableResult {
>/**
> * return JobClient if a Flink job is submitted
> * (for DML/DQL statement), else return empty (e.g. DDL).
> */
>Optional getJobClient();
>  
>/** 
> * Get the schema of result. 
> */
> TableSchema getTableSchema();
>  
> /**
>  * return the ResultKind which can avoid custom parsing of
>  * an "OK" row in programming
>  */
> ResultKind getResultKind();
>  
>  /**
>   * Get the result contents as an iterable rows.
>   */
> Iterator collect();
>  
> /**
>  * Print the result contents.
>  */
> void print();
> }
> /**
>  * ResultKind defines the types of the result.
>  */
> public enum ResultKind {
> // for DDL, DCL and statements with a simple "OK"
> SUCCESS,
>  
> // rows with important content are available (DML, DQL)
> SUCCESS_WITH_CONTENT
> }
> {code}



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


[GitHub] [flink] flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810#issuecomment-616097140
 
 
   
   ## CI report:
   
   * 8e8584c51dcb2bfd4967c4299550b01f32b013ee Travis: 
[FAILURE](https://travis-ci.com/github/flink-ci/flink/builds/160894187) Azure: 
[PENDING](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7730)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Updated] (FLINK-17137) Support mini batch for WindowOperator in blink planner

2020-04-19 Thread Benchao Li (Jira)


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

Benchao Li updated FLINK-17137:
---
Description: 
Currently only regular aggregate and deduplicate support mini batch. 
WindowOperator is a very frequently used operator in Flink, it's very helpful 
to support mini batch for it.

Design document:  
https://docs.google.com/document/d/1GYlrg8dkYcw5fuq1HptdA3lygXrS_VRbnI8NXoEtZCg/edit?usp=sharing

cc [~jark]

  was:
Currently only regular aggregate and deduplicate support mini batch. 
WindowOperator is a very frequently used operator in Flink, it's very helpful 
to support mini batch for it.

 

cc [~jark]


> Support mini batch for WindowOperator in blink planner
> --
>
> Key: FLINK-17137
> URL: https://issues.apache.org/jira/browse/FLINK-17137
> Project: Flink
>  Issue Type: Improvement
>  Components: Table SQL / Planner, Table SQL / Runtime
>Reporter: Benchao Li
>Priority: Major
>
> Currently only regular aggregate and deduplicate support mini batch. 
> WindowOperator is a very frequently used operator in Flink, it's very helpful 
> to support mini batch for it.
> Design document:  
> https://docs.google.com/document/d/1GYlrg8dkYcw5fuq1HptdA3lygXrS_VRbnI8NXoEtZCg/edit?usp=sharing
> cc [~jark]



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


[jira] [Commented] (FLINK-17188) Failed to download conda when running python tests

2020-04-19 Thread Dian Fu (Jira)


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

Dian Fu commented on FLINK-17188:
-

Another instance: 
https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_apis/build/builds/7724/logs/105

It timed out during downloading flake8

> Failed to download conda when running python tests
> --
>
> Key: FLINK-17188
> URL: https://issues.apache.org/jira/browse/FLINK-17188
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dawid Wysakowicz
>Assignee: Huang Xingbo
>Priority: Major
>  Labels: test-stability
> Fix For: 1.11.0
>
>
> https://dev.azure.com/rmetzger/Flink/_build/results?buildId=7549&view=logs&j=9cada3cb-c1d3-5621-16da-0f718fb86602&t=14487301-07d2-5d56-5690-6dfab9ffd4d9
> This pipeline failed to download conda
> If this issue starts appearing more often we should come up with some 
> solution for those kinds of problems.
> {code}
> CondaHTTPError: HTTP 000 CONNECTION FAILED for url 
> 
> Elapsed: -
> An HTTP error occurred when trying to retrieve this URL.
> HTTP errors are often intermittent, and a simple retry will get you on your 
> way.
> conda install sphinx failed please try to exec the script again.  
>   if failed many times, you can try to exec in the form of sudo 
> ./lint-python.sh -f
> PYTHON exited with EXIT CODE: 1.
> {code}



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


[jira] [Commented] (FLINK-17188) Failed to download conda when running python tests

2020-04-19 Thread Dian Fu (Jira)


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

Dian Fu commented on FLINK-17188:
-

The following instance report "Maven produced no output for 300 seconds." 
during downloading sphinx.

Instance: 
https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_apis/build/builds/7726/logs/152

> Failed to download conda when running python tests
> --
>
> Key: FLINK-17188
> URL: https://issues.apache.org/jira/browse/FLINK-17188
> Project: Flink
>  Issue Type: Bug
>  Components: API / Python, Build System / Azure Pipelines
>Reporter: Dawid Wysakowicz
>Assignee: Huang Xingbo
>Priority: Major
>  Labels: test-stability
> Fix For: 1.11.0
>
>
> https://dev.azure.com/rmetzger/Flink/_build/results?buildId=7549&view=logs&j=9cada3cb-c1d3-5621-16da-0f718fb86602&t=14487301-07d2-5d56-5690-6dfab9ffd4d9
> This pipeline failed to download conda
> If this issue starts appearing more often we should come up with some 
> solution for those kinds of problems.
> {code}
> CondaHTTPError: HTTP 000 CONNECTION FAILED for url 
> 
> Elapsed: -
> An HTTP error occurred when trying to retrieve this URL.
> HTTP errors are often intermittent, and a simple retry will get you on your 
> way.
> conda install sphinx failed please try to exec the script again.  
>   if failed many times, you can try to exec in the form of sudo 
> ./lint-python.sh -f
> PYTHON exited with EXIT CODE: 1.
> {code}



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


[GitHub] [flink] flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce 
the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811#issuecomment-616107576
 
 
   
   ## CI report:
   
   * 40bd2693a11d52097fd55b23173710f35965dcb7 Travis: 
[PENDING](https://travis-ci.com/github/flink-ci/flink/builds/160897124) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7732)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Assigned] (FLINK-17226) Remove Prometheus relocations

2020-04-19 Thread Chesnay Schepler (Jira)


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

Chesnay Schepler reassigned FLINK-17226:


Assignee: molsion mo

> Remove Prometheus relocations
> -
>
> Key: FLINK-17226
> URL: https://issues.apache.org/jira/browse/FLINK-17226
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Assignee: molsion mo
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Prometheus reporters as plugins we should remove the 
> shade-plugin configuration/relocations.



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


[jira] [Assigned] (FLINK-17227) Remove Datadog relocations

2020-04-19 Thread Chesnay Schepler (Jira)


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

Chesnay Schepler reassigned FLINK-17227:


Assignee: molsion mo

> Remove Datadog relocations
> --
>
> Key: FLINK-17227
> URL: https://issues.apache.org/jira/browse/FLINK-17227
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Assignee: molsion mo
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Datadog reporter as a plugin we should remove the 
> shade-plugin configuration/relocations.



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


[jira] [Commented] (FLINK-17226) Remove Prometheus relocations

2020-04-19 Thread Chesnay Schepler (Jira)


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

Chesnay Schepler commented on FLINK-17226:
--

??Will there be other effects after removal???

This removal shouldn't affect users, so long as they load the reporter as a 
plugin.

The purpose of the relocations is to move dependencies into a separate package 
to prevent dependency clashes. Now that reporters can be loaded as plugins, 
which run in their own class-loader (and are hence isolated from other jars), 
these clashes can no longer occur, rending the relocations unnecessary.

> Remove Prometheus relocations
> -
>
> Key: FLINK-17226
> URL: https://issues.apache.org/jira/browse/FLINK-17226
> Project: Flink
>  Issue Type: Sub-task
>  Components: Runtime / Metrics
>Reporter: Chesnay Schepler
>Assignee: molsion mo
>Priority: Major
> Fix For: 1.11.0
>
>
> Now that we load the Prometheus reporters as plugins we should remove the 
> shade-plugin configuration/relocations.



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


[GitHub] [flink] flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make YarnResourceManager starts workers using WorkerResourceSpec requested by SlotManager

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11353: [FLINK-16438][yarn] Make 
YarnResourceManager starts workers using WorkerResourceSpec requested by 
SlotManager
URL: https://github.com/apache/flink/pull/11353#issuecomment-596455079
 
 
   
   ## CI report:
   
   * c4edf089b07a5a95a8cc53c6a32bd98ff3f7dde0 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160893255) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7728)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11811: [FLINK-16658][FLINK-16660] Introduce 
the ApplicationDispatcherBootstrap and wire it to StandaloneJobEntrypoint
URL: https://github.com/apache/flink/pull/11811#issuecomment-616107576
 
 
   
   ## CI report:
   
   * 40bd2693a11d52097fd55b23173710f35965dcb7 Travis: 
[FAILURE](https://travis-ci.com/github/flink-ci/flink/builds/160897124) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7732)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython support for primitive data types

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11809: [FLINK-17118][python] Add Cython 
support for primitive data types
URL: https://github.com/apache/flink/pull/11809#issuecomment-616094062
 
 
   
   ## CI report:
   
   * ce14ff9be8664c8d5bad912e8fbfa3881e0cc339 Travis: 
[SUCCESS](https://travis-ci.com/github/flink-ci/flink/builds/160893292) Azure: 
[SUCCESS](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7729)
 
   
   
   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


With regards,
Apache Git Services


[GitHub] [flink] KarmaGYZ commented on issue #11621: [FLINK-16788][Connector]ElasticSearch Connector SQL DDL add optional config (eg: enable-auth/username/password)

2020-04-19 Thread GitBox
KarmaGYZ commented on issue #11621: [FLINK-16788][Connector]ElasticSearch 
Connector SQL DDL add optional config (eg: enable-auth/username/password)
URL: https://github.com/apache/flink/pull/11621#issuecomment-616130401
 
 
   Thanks for this work, @zhisheng17 .
   - It seems the 'connector.enable-auth' could be removed.
   - Could we also port this feature to elasticsearch 5?
   - It better to follow the "rebase" mode instead of "merge".


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


With regards,
Apache Git Services


[GitHub] [flink] KurtYoung commented on issue #11802: [FLINK-17197][runtime] switch ContinuousFileReaderOperator state to FAILED on error

2020-04-19 Thread GitBox
KurtYoung commented on issue #11802: [FLINK-17197][runtime] switch 
ContinuousFileReaderOperator state to FAILED on error
URL: https://github.com/apache/flink/pull/11802#issuecomment-616133917
 
 
   I've tested this patch and confirm this can solve another similar issue: 
https://issues.apache.org/jira/browse/FLINK-17234


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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-17182) RemoteInputChannelTest.testConcurrentOnSenderBacklogAndRecycle fail on azure

2020-04-19 Thread Yun Gao (Jira)


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

Yun Gao commented on FLINK-17182:
-

This should be caused by when the unfulfilled buffer is fulfilled by recycled 
exclusive buffers, the status of waiting on buffer pool is not cleared, thus it 
could not reuse buffer returned by itself to buffer pool. A simulated case 
would be:

Suppose initially both the input channel and buffer pool have no buffers, which 
the case in this test. We also temporarily ignore the initial credit, which 
does not affect the issue. 
 # inputChannel.onSenderBacklog(2), which makes the input channel start waiting 
on the buffer pool
 # one buffer is recycled to the buffer pool and assigned to the input channel.
 # one exclusive buffer is recycle and returned to the input channel. With 
current implementation the input channel will not stop waiting, even if its 
available buffers are already equal to the required.
 # one exclusive buffer is recycled and return to the input channel. input 
channel will return one buffer to the buffer pool.
 # inputChannel.onSenderBacklog(3), thus one more buffer is required, however, 
since the channel is still waiting on the buffer pool, it cannot request the 
available buffer in the buffer pool. There is also no other chances to assign 
this buffer to the input channel. 

Thus, one buffer is left in the buffer pool and cannot assign to the input 
channel.

> RemoteInputChannelTest.testConcurrentOnSenderBacklogAndRecycle fail on azure
> 
>
> Key: FLINK-17182
> URL: https://issues.apache.org/jira/browse/FLINK-17182
> Project: Flink
>  Issue Type: Bug
>  Components: Runtime / Network
>Reporter: Dawid Wysakowicz
>Assignee: Yun Gao
>Priority: Critical
>  Labels: test-stability
> Fix For: 1.11.0
>
>
> https://dev.azure.com/rmetzger/Flink/_build/results?buildId=7546&view=logs&j=0da23115-68bb-5dcd-192c-bd4c8adebde1&t=d2c1c472-9d7b-5913-b8e4-461f3092fb7a
> {code}
> [ERROR] Tests run: 21, Failures: 1, Errors: 0, Skipped: 0, Time elapsed: 
> 3.943 s <<< FAILURE! - in 
> org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannelTest
> [ERROR] 
> testConcurrentOnSenderBacklogAndRecycle(org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannelTest)
>   Time elapsed: 0.011 s  <<< FAILURE!
> java.lang.AssertionError: There should be 248 buffers available in channel. 
> expected:<248> but was:<238>
>   at org.junit.Assert.fail(Assert.java:88)
>   at org.junit.Assert.failNotEquals(Assert.java:834)
>   at org.junit.Assert.assertEquals(Assert.java:645)
>   at 
> org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannelTest.testConcurrentOnSenderBacklogAndRecycle(RemoteInputChannelTest.java:869)
>   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.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:50)
>   at 
> org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:12)
>   at 
> org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:47)
>   at 
> org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:17)
>   at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:325)
>   at 
> org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:78)
>   at 
> org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:57)
>   at org.junit.runners.ParentRunner$3.run(ParentRunner.java:290)
>   at org.junit.runners.ParentRunner$1.schedule(ParentRunner.java:71)
>   at org.junit.runners.ParentRunner.runChildren(ParentRunner.java:288)
>   at org.junit.runners.ParentRunner.access$000(ParentRunner.java:58)
>   at org.junit.runners.ParentRunner$2.evaluate(ParentRunner.java:268)
>   at org.junit.runners.ParentRunner.run(ParentRunner.java:363)
>   at 
> org.apache.maven.surefire.junit4.JUnit4Provider.execute(JUnit4Provider.java:365)
>   at 
> org.apache.maven.surefire.junit4.JUnit4Provider.executeWithRerun(JUnit4Provider.java:273)
>   at 
> org.apache.maven.surefire.junit4.JUnit4Provider.executeTestSet(JUnit4Provider.java:238)
>   at 
> org.apache.maven.surefire.junit4.JUnit4Provider.invoke(JUnit4Provider.java:159)
>   at 
> org.apache.maven.surefire.booter.ForkedBooter.invokeProviderInSameClassLoader(ForkedBooter.java:384)
>   at 
> o

[GitHub] [flink] flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub, e2e] CheckPubSubEmulatorTest is flaky on Azure

2020-04-19 Thread GitBox
flinkbot edited a comment on issue #11810: [FLINK-16572] [pubsub,e2e] 
CheckPubSubEmulatorTest is flaky on Azure
URL: https://github.com/apache/flink/pull/11810#issuecomment-616097140
 
 
   
   ## CI report:
   
   * 8e8584c51dcb2bfd4967c4299550b01f32b013ee Travis: 
[FAILURE](https://travis-ci.com/github/flink-ci/flink/builds/160894187) Azure: 
[FAILURE](https://dev.azure.com/rmetzger/5bd3ef0a-4359-41af-abca-811b04098d2e/_build/results?buildId=7730)
 
   
   
   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


With regards,
Apache Git Services


[jira] [Commented] (FLINK-16933) No suitable driver found for jdbc:xxx

2020-04-19 Thread JinxinTang (Jira)


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

JinxinTang commented on FLINK-16933:


Could you please provide simple method to reproduce the problem quickly, or 
picture attached to describe the detail?

> No suitable driver found for jdbc:xxx
> -
>
> Key: FLINK-16933
> URL: https://issues.apache.org/jira/browse/FLINK-16933
> Project: Flink
>  Issue Type: Bug
>  Components: API / DataStream
>Affects Versions: 1.9.0
> Environment: CentOS Linux release 7.7.1908 (Core)
>Reporter: morgan
>Priority: Major
>
> For example, there are two streaming jobs A and B.
> When A calculation is running, I submit B, at this time, an exception will be 
> thrown, Caused by: java.sql.SQLException: No suitable driver found for jdbc: 
> clickhouse: // host: 8123 / data. When stopping flink ./stop-cluster.sh. Then 
> restart ./start-cluster.sh. When flink is not running any tasks, submit B, 
> and B is successfully executed. But if you execute B multiple times, Caused 
> by: java.sql.SQLException: No suitable driver found for jdbc: clickhouse: // 
> host: 8123 / data will also be thrown. Both B and A depend on clickhouse4j in 
> the common. A submission can run normally, but B can only be executed when 
> restart and flink does not contain other tasks, which seems strange. I 
> checked flink / lib / and clickhouse4j-1.4.1.jar has been added. I tried to 
> package clickhouse4j-1.4.1.jar into the job, but still couldn't solve this 
> problem. I tried to add it to jre / lib / ext and added it to the classpath. 
> The problem was not solved. But I executed in the local environment idea and 
> did not throw any exception.



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


  1   2   3   >