[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26780)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Commented] (FLINK-24693) Update Chinese version of "Checkpoints" and "Checkpointing" page

2021-11-19 Thread wulei0302 (Jira)


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

wulei0302 commented on FLINK-24693:
---

[~pnowojski]  Hi, I have done the translation of other pages of Flink, I hope 
to continue to translate checkpoint, please assign me,thanks.

> Update Chinese version of "Checkpoints" and "Checkpointing" page
> 
>
> Key: FLINK-24693
> URL: https://issues.apache.org/jira/browse/FLINK-24693
> Project: Flink
>  Issue Type: Improvement
>  Components: chinese-translation, Documentation
>Affects Versions: 1.15.0, 1.14.1
>Reporter: Piotr Nowojski
>Priority: Critical
>
> Page {{content.zh/docs/ops/state/checkpoints.md}} and 
> {{content.zh/docs/dev/datastream/fault-tolerance/checkpointing.md}} are very 
> much out of date and out of sync of theirs english counterparts.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink-ml] lindong28 commented on a change in pull request #28: [Flink-24556] Add Estimator and Transformer for logistic regression

2021-11-19 Thread GitBox


lindong28 commented on a change in pull request #28:
URL: https://github.com/apache/flink-ml/pull/28#discussion_r753633697



##
File path: 
flink-ml-lib/src/main/java/org/apache/flink/ml/common/linalg/BLAS.java
##
@@ -0,0 +1,83 @@
+/*
+ * 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.ml.common.linalg;
+
+import org.apache.flink.util.Preconditions;
+
+/** A utility class that provides BLAS routines over matrices and vectors. */
+public class BLAS {
+
+/** For level-1 routines, we use Java implementation. */
+private static final com.github.fommil.netlib.BLAS NATIVE_BLAS =

Review comment:
   Spark has updated its BLAS library dependency to use e.g. 
`dev.ludovic.netlib.BLAS`. We can find explanation in its commit message and 
JIRA description.
   
   The Naive Bayes PR follows Spark's approach. Maybe we can do the same here?
   

##
File path: 
flink-ml-lib/src/main/java/org/apache/flink/ml/common/param/linear/HasMaxIter.java
##
@@ -0,0 +1,42 @@
+/*
+ * 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.ml.common.param.linear;
+
+import org.apache.flink.ml.param.IntParam;
+import org.apache.flink.ml.param.Param;
+import org.apache.flink.ml.param.ParamValidators;
+import org.apache.flink.ml.param.WithParams;
+
+/** Interface for the shared maxIteration param. */
+public interface HasMaxIter extends WithParams {

Review comment:
   Can we re-use the existing `HasMaxIter` in the package 
`org.apache.flink.ml.common.param`?
   
   Is there any reason we need to put these params in the package `*.linear`? 
It looks like more (if not all) of these parameters are general to all types of 
algorithms.

##
File path: 
flink-ml-lib/src/main/java/org/apache/flink/ml/classification/linear/LogisticGradient.java
##
@@ -0,0 +1,109 @@
+/*
+ * 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.ml.classification.linear;
+
+import org.apache.flink.api.java.tuple.Tuple2;
+import org.apache.flink.api.java.tuple.Tuple3;
+import org.apache.flink.ml.common.linalg.BLAS;
+
+import java.io.Serializable;
+
+/** Logistic gradient. */
+public class LogisticGradient implements Serializable {
+private static final long serialVersionUID = 1178693053439209380L;
+
+/** L1 regularization term. */
+private final double l1;
+
+/** L2 regularization term. */
+private final double l2;
+
+public LogisticGradient(double l1, double l2) {
+this.l1 = l1;
+this.l2 = l2;
+}
+
+/**
+ * Computes loss and weightSum on a set of samples.
+ *
+ * @param labeledData a sample set of train data.
+ * 

[GitHub] [flink] flinkbot edited a comment on pull request #17844: [FLINK-24925] [core] SingleThreadAccessCheckingTypeSerializer#equals() compares different data type.

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 3375518299dfe28beb558a4a1088c6cdd297b7ee Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26778)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink-ml] lindong28 commented on a change in pull request #30: [FLINK-24845] Add allreduce utility function in FlinkML

2021-11-19 Thread GitBox


lindong28 commented on a change in pull request #30:
URL: https://github.com/apache/flink-ml/pull/30#discussion_r753631808



##
File path: 
flink-ml-lib/src/main/java/org/apache/flink/ml/common/datastream/AllReduceUtils.java
##
@@ -0,0 +1,286 @@
+/*
+ * 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.ml.common.datastream;
+
+import org.apache.flink.api.common.functions.RichFlatMapFunction;
+import org.apache.flink.api.common.typeinfo.BasicTypeInfo;
+import org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo;
+import org.apache.flink.api.common.typeinfo.TypeInformation;
+import org.apache.flink.api.java.tuple.Tuple3;
+import org.apache.flink.api.java.tuple.Tuple4;
+import org.apache.flink.api.java.typeutils.TupleTypeInfo;
+import org.apache.flink.streaming.api.datastream.DataStream;
+import org.apache.flink.streaming.api.operators.AbstractStreamOperator;
+import org.apache.flink.streaming.api.operators.BoundedOneInput;
+import org.apache.flink.streaming.api.operators.OneInputStreamOperator;
+import org.apache.flink.streaming.runtime.streamrecord.StreamRecord;
+import org.apache.flink.util.Collector;
+
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Applies all-reduce on a DataStream where each partition contains only one 
double array.
+ *
+ * AllReduce is a communication primitive widely used in MPI. In this 
implementation, all workers
+ * do reduce on a partition of the whole data and they all get the final 
reduce result. In detail,
+ * we split each double array into chunks of fixed size buffer (4KB by 
default) and let each subtask
+ * handle several chunks.
+ *
+ * There're mainly three stages:
+ * 1. All workers send their partial data to other workers for reduce.
+ * 2. All workers do reduce on all data it received and then send partial 
results to others.
+ * 3. All workers merge partial results into final result.
+ */
+public class AllReduceUtils {
+
+private static final int TRANSFER_BUFFER_SIZE = 1024 * 4;
+
+/**
+ * Applies allReduce on the input data stream. The input data stream is 
supposed to contain one
+ * double array in each partition. The result data stream has the same 
parallelism as the input,
+ * where each partition contains one double array that sums all of the 
double arrays in the
+ * input data stream.
+ *
+ * Note that we throw exception when one of the following two cases 
happen:
+ * 1. There exists one partition that contains more than one double 
array.
+ * 2. The length of double array is not consistent among all 
partitions.
+ *
+ * @param input The input data stream.
+ * @return The result data stream.
+ */
+public static DataStream allReduce(DataStream input) {
+// chunkId, totalElements, partitionedArray
+DataStream> allReduceSend =
+input.flatMap(new AllReduceSend()).name("all-reduce-send");
+
+// taskId, chunkId, totalElements, partitionedArray
+DataStream> allReduceSum =
+allReduceSend
+.partitionCustom(
+(chunkId, numPartitions) -> chunkId % 
numPartitions, x -> x.f0)
+.transform(
+"all-reduce-sum",
+new TupleTypeInfo<>(
+BasicTypeInfo.INT_TYPE_INFO,
+BasicTypeInfo.INT_TYPE_INFO,
+BasicTypeInfo.INT_TYPE_INFO,
+
PrimitiveArrayTypeInfo.DOUBLE_PRIMITIVE_ARRAY_TYPE_INFO),
+new AllReduceSum())
+.name("all-reduce-sum");
+
+return allReduceSum
+.partitionCustom((taskIdx, numPartitions) -> taskIdx % 
numPartitions, x -> x.f0)
+.transform(
+"all-reduce-recv", TypeInformation.of(double[].class), 
new AllReduceRecv())
+.name("all-reduce-recv");
+}
+
+/**
+ * Splits each double array into multiple chunks and send each chunk to 
the corresponding
+ * partition.
+ */
+private stat

[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26780)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Commented] (FLINK-24935) Python module failed to compile due to "Could not create local repository"

2021-11-19 Thread Yun Gao (Jira)


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

Yun Gao commented on FLINK-24935:
-

Hi [~chesnay]~ Sorry I might not express myself clear, I mean before 11-16, 
compiling python is also use `/__w/1/.m2/repository` and could be successful, 
but after 11-16 it is changed to `/home/vsts/work/1/.m2/repository` and fail. 
Do we have some change to the pipeline on 11-15/16~ ?

> Python module failed to compile due to "Could not create local repository"
> --
>
> Key: FLINK-24935
> URL: https://issues.apache.org/jira/browse/FLINK-24935
> Project: Flink
>  Issue Type: Bug
>  Components: Build System / Azure Pipelines
>Affects Versions: 1.12.5
>Reporter: Yun Gao
>Priority: Major
>  Labels: test-stability
>
> {code:java}
> Invoking mvn with 'mvn -Dmaven.wagon.http.pool=false --settings 
> /__w/1/s/tools/ci/google-mirror-settings.xml 
> -Dorg.slf4j.simpleLogger.showDateTime=true 
> -Dorg.slf4j.simpleLogger.dateTimeFormat=HH:mm:ss.SSS 
> -Dorg.slf4j.simpleLogger.log.org.apache.maven.cli.transfer.Slf4jMavenTransferListener=warn
>  --no-snapshot-updates -B -Dhadoop.version=2.8.3 -Dinclude_hadoop_aws 
> -Dscala-2.11  clean deploy 
> -DaltDeploymentRepository=validation_repository::default::file:/tmp/flink-validation-deployment
>  -Dmaven.repo.local=/home/vsts/work/1/.m2/repository 
> -Dflink.convergence.phase=install -Pcheck-convergence -Dflink.forkCount=2 
> -Dflink.forkCountTestPackage=2 -Dmaven.javadoc.skip=true -U -DskipTests'
> [ERROR] Could not create local repository at /home/vsts/work/1/.m2/repository 
> -> [Help 1]
> [ERROR] 
> [ERROR] To see the full stack trace of the errors, re-run Maven with the -e 
> switch.
> [ERROR] Re-run Maven using the -X switch to enable full debug logging.
> [ERROR] 
> [ERROR] For more information about the errors and possible solutions, please 
> read the following articles:
> [ERROR] [Help 1] 
> http://cwiki.apache.org/confluence/display/MAVEN/LocalRepositoryNotAccessibleException
>  {code}
> [https://dev.azure.com/apache-flink/apache-flink/_build/results?buildId=26625&view=logs&j=a29bcfe1-064d-50b9-354f-07802213a3c0&t=47ff6576-c9dc-5eab-9db8-183dcca3bede]



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Comment Edited] (FLINK-21583) Allow comments in CSV format without having to ignore parse errors

2021-11-19 Thread liwei li (Jira)


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

liwei li edited comment on FLINK-21583 at 11/20/21, 3:52 AM:
-

This seems to be currently supported.

I created the following case to test :

csv file :

 
{code:java}
#comment1
1,lisi
2,wangwu
3,zhangsan
#comment2{code}
flink sql :

 
{code:java}
tEnv.executeSql(
  """
|
|CREATE TABLE MyUserTable (
|  id INT,
|  name STRING
|) WITH (
|  'connector' = 'filesystem',   
|  'path' = '/test/test/csv', 
|  'csv.allow-comments' = 'true',
|  'format' = 'csv'
|)
|""".stripMargin) {code}
 

Here's what I got:

 
{code:java}
++--+---+
| op |          id |               name |
++--+---+
| +I |           3 |    zhangsan |
| +I |           2 |           wangwu |
| +I |           1 |               lisi |
++-++
3 rows in set {code}
 

The result is the same as what we expected. Can I assume that I only need to 
modify the document?

If my understanding is wrong, please give some guidance, thank you.

[~nkruber] [~jark] 

 

 

 


was (Author: liliwei):
This seems to be currently supported.

I created the following case to test :

csv file :

 
{code:java}
#comment1
1,lisi
2,wangwu
3,zhangsan
#comment2{code}
flink sql :

 
{code:java}
tEnv.executeSql(
  """
|
|CREATE TABLE MyUserTable (
|  id INT,
|  name STRING
|) WITH (
|  'connector' = 'filesystem',   
|  'path' = '/test/test/csv', 
|  'csv.allow-comments' = 'true',
|  'format' = 'csv'
|)
|""".stripMargin) {code}
 

Here's what I got:

 
{code:java}
++--+---+
| op |          id |               name |
++--+---+
| +I |           3 |    zhangsan |
| +I |           2 |           wangwu |
| +I |           1 |               lisi |
++-++
3 rows in set {code}
The result is the same as what we expected. Can I assume that I only need to 
modify the document?

If my understanding is wrong, please give some guidance, thank you.

[~nkruber] [~jark] 

 

 

 

> Allow comments in CSV format without having to ignore parse errors
> --
>
> Key: FLINK-21583
> URL: https://issues.apache.org/jira/browse/FLINK-21583
> Project: Flink
>  Issue Type: Improvement
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), Table 
> SQL / Ecosystem
>Affects Versions: 1.12.1
>Reporter: Nico Kruber
>Assignee: liwei li
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> Currently, when you pass {{'csv.allow-comments' = 'true'}} to a table 
> definition, you also have to set {{'csv.ignore-parse-errors' = 'true'}} to 
> actually skip the commented-out line (and the docs mention this prominently 
> as well). This, however, may mask actual parsing errors that you want to be 
> notified of.
> I would like to propose that {{allow-comments}} actually also skips the 
> commented-out lines automatically because these shouldn't be used anyway.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Commented] (FLINK-21583) Allow comments in CSV format without having to ignore parse errors

2021-11-19 Thread liwei li (Jira)


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

liwei li commented on FLINK-21583:
--

This seems to be currently supported.

I created the following case to test :

csv file :

 
{code:java}
#comment1
1,lisi
2,wangwu
3,zhangsan
#comment2{code}
flink sql :

 
{code:java}
tEnv.executeSql(
  """
|
|CREATE TABLE MyUserTable (
|  id INT,
|  name STRING
|) WITH (
|  'connector' = 'filesystem',   
|  'path' = '/test/test/csv', 
|  'csv.allow-comments' = 'true',
|  'format' = 'csv'
|)
|""".stripMargin) {code}
 

Here's what I got:

 
{code:java}
++--+---+
| op |          id |               name |
++--+---+
| +I |           3 |    zhangsan |
| +I |           2 |           wangwu |
| +I |           1 |               lisi |
++-++
3 rows in set {code}
The result is the same as what we expected. Can I assume that I only need to 
modify the document?

If my understanding is wrong, please give some guidance, thank you.

[~nkruber] [~jark] 

 

 

 

> Allow comments in CSV format without having to ignore parse errors
> --
>
> Key: FLINK-21583
> URL: https://issues.apache.org/jira/browse/FLINK-21583
> Project: Flink
>  Issue Type: Improvement
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile), Table 
> SQL / Ecosystem
>Affects Versions: 1.12.1
>Reporter: Nico Kruber
>Assignee: liwei li
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> Currently, when you pass {{'csv.allow-comments' = 'true'}} to a table 
> definition, you also have to set {{'csv.ignore-parse-errors' = 'true'}} to 
> actually skip the commented-out line (and the docs mention this prominently 
> as well). This, however, may mask actual parsing errors that you want to be 
> notified of.
> I would like to propose that {{allow-comments}} actually also skips the 
> commented-out lines automatically because these shouldn't be used anyway.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink-ml] lindong28 commented on pull request #20: [FLINK-23959][FLIP-175] Compose Estimator/Model/AlgoOperator from DAG of Estimator/Model/AlgoOperator

2021-11-19 Thread GitBox


lindong28 commented on pull request #20:
URL: https://github.com/apache/flink-ml/pull/20#issuecomment-974586067


   @gaoyunhaii Could you help review this PR when you get time? Thanks!


-- 
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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   * f51e8519e195627c7fe098b3f5332bae905c2a0f UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] Aitozi commented on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


Aitozi commented on pull request #17554:
URL: https://github.com/apache/flink/pull/17554#issuecomment-974585072


   @wangyang0918 I have addressed the comments, please take a look when you are 
free 


-- 
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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26779)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * fceb0c59da025114818f57ef73d73b1d030e8509 Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=25407)
 
   * 720b4c0be3f96f2e6b17fffe264ffd4bc7a7dee5 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] Aitozi commented on a change in pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


Aitozi commented on a change in pull request #17554:
URL: https://github.com/apache/flink/pull/17554#discussion_r753626375



##
File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/KubernetesClusterDescriptor.java
##
@@ -256,39 +268,35 @@ private String getWebMonitorAddress(Configuration 
configuration) throws Exceptio
 flinkConfig.get(JobManagerOptions.PORT));
 }
 
+final KubernetesJobManagerParameters kubernetesJobManagerParameters =
+new KubernetesJobManagerParameters(flinkConfig, 
clusterSpecification);
+
+final FlinkPod podTemplate =
+kubernetesJobManagerParameters
+.getPodTemplateFilePath()
+.map(
+file ->
+
KubernetesUtils.loadPodFromTemplateFile(
+client, file, 
Constants.MAIN_CONTAINER_NAME))
+.orElse(new FlinkPod.Builder().build());
+final KubernetesJobManagerSpecification kubernetesJobManagerSpec =
+
KubernetesJobManagerFactory.buildKubernetesJobManagerSpecification(
+podTemplate, kubernetesJobManagerParameters);
+
+client.createJobManagerComponent(kubernetesJobManagerSpec);
+
+return createClusterClientProvider(clusterId);
+}
+
+private void killClusterSilently(Throwable throwable) {
 try {
-final KubernetesJobManagerParameters 
kubernetesJobManagerParameters =
-new KubernetesJobManagerParameters(flinkConfig, 
clusterSpecification);
-
-final FlinkPod podTemplate =
-kubernetesJobManagerParameters
-.getPodTemplateFilePath()
-.map(
-file ->
-
KubernetesUtils.loadPodFromTemplateFile(
-client, file, 
Constants.MAIN_CONTAINER_NAME))
-.orElse(new FlinkPod.Builder().build());
-final KubernetesJobManagerSpecification kubernetesJobManagerSpec =
-
KubernetesJobManagerFactory.buildKubernetesJobManagerSpecification(
-podTemplate, kubernetesJobManagerParameters);
-
-client.createJobManagerComponent(kubernetesJobManagerSpec);
-
-return createClusterClientProvider(clusterId);
+LOG.warn(
+"Failed to create the Kubernetes cluster \"{}\", try to 
clean up the residual resources.",
+clusterId,
+throwable);

Review comment:
   removed




-- 
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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] Aitozi commented on a change in pull request #17554: [FLINK-24624][Kubernetes]Kill cluster when starting kubernetes session or application cluster failed

2021-11-19 Thread GitBox


Aitozi commented on a change in pull request #17554:
URL: https://github.com/apache/flink/pull/17554#discussion_r753626315



##
File path: 
flink-kubernetes/src/main/java/org/apache/flink/kubernetes/KubernetesClusterDescriptor.java
##
@@ -205,17 +211,23 @@ private String getWebMonitorAddress(Configuration 
configuration) throws Exceptio
 Preconditions.checkArgument(pipelineJars.size() == 1, "Should only 
have one jar");
 }
 
-final ClusterClientProvider clusterClientProvider =
-deployClusterInternal(
-KubernetesApplicationClusterEntrypoint.class.getName(),
-clusterSpecification,
-false);
+ClusterClientProvider clusterClientProvider;
+try {
+clusterClientProvider =
+deployClusterInternal(
+
KubernetesApplicationClusterEntrypoint.class.getName(),
+clusterSpecification,
+false);
 
-try (ClusterClient clusterClient = 
clusterClientProvider.getClusterClient()) {
-LOG.info(
-"Create flink application cluster {} successfully, 
JobManager Web Interface: {}",
-clusterId,
-clusterClient.getWebInterfaceURL());
+try (ClusterClient clusterClient = 
clusterClientProvider.getClusterClient()) {
+LOG.info(
+"Create flink application cluster {} successfully, 
JobManager Web Interface: {}",
+clusterId,
+clusterClient.getWebInterfaceURL());
+}
+} catch (Exception e) {

Review comment:
   Good suggestion 👍




-- 
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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Updated] (FLINK-23959) FLIP-175: Compose Estimator/Model/AlgoOperator from DAG of Estimator/Model/AlgoOperator

2021-11-19 Thread Dong Lin (Jira)


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

Dong Lin updated FLINK-23959:
-
Summary: FLIP-175: Compose Estimator/Model/AlgoOperator from DAG of 
Estimator/Model/AlgoOperator  (was: FLIP-175: Add GraphBuilder to compose 
Estimator/Transformer/AlgoOperator from a DAG of stages)

> FLIP-175: Compose Estimator/Model/AlgoOperator from DAG of 
> Estimator/Model/AlgoOperator
> ---
>
> Key: FLINK-23959
> URL: https://issues.apache.org/jira/browse/FLINK-23959
> Project: Flink
>  Issue Type: Improvement
>  Components: Library / Machine Learning
>Reporter: Dong Lin
>Priority: Major
>  Labels: pull-request-available
>
> The FLIP design doc can be found at 
> https://cwiki.apache.org/confluence/pages/viewpage.action?pageId=181311363.
> The existing Flink ML library allows users to compose an 
> Estimator/Transformer from a pipeline (i.e. linear sequence) of 
> Estimator/Transformer. Users only need to construct this Pipeline once and 
> generate the corresponding PipelineModel, without having to explicitly 
> construct the fitted PipelineModel as a linear sequence of stages. However, 
> in order to train a DAG of Estimator/Transformer and uses the trained model 
> for inference, users currently need to construct the DAG twice, once for the 
> training logic and once for the inference logic. This experience is inferior 
> to the experience of training and using a chain of Estimator/Transformer. In 
> addition to requiring more work from users, this approach is more error prone 
> because the DAG for the training logic may be inconsistent from the DAG for 
> the inference logic.
> In order to address the issues described above, we propose to add several 
> helper classes that allow users to compose Estimator/Transformer/AlgoOperator 
> from a DAG of Estimator/Transformer/AlgoOperator.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] hililiwei commented on pull request #17613: [FLINK-24536][Table SQL/Planner] flink sql support bang equal '!='

2021-11-19 Thread GitBox


hililiwei commented on pull request #17613:
URL: https://github.com/apache/flink/pull/17613#issuecomment-974573248


   @RocMarshal @MartijnVisser could you PTAL?


-- 
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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Commented] (FLINK-24758) filesystem sink: partition.time-extractor.kind support "yyyyMMdd"

2021-11-19 Thread liwei li (Jira)


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

liwei li commented on FLINK-24758:
--

[~lzljs3620320] [~MartijnVisser] [~nobleyd] could you please help to review? 
thx.

> filesystem sink: partition.time-extractor.kind support "MMdd"
> -
>
> Key: FLINK-24758
> URL: https://issues.apache.org/jira/browse/FLINK-24758
> Project: Flink
>  Issue Type: Improvement
>  Components: Connectors / FileSystem
>Reporter: Jingsong Lee
>Assignee: liwei li
>Priority: Major
>  Labels: pull-request-available
>
> Now, only supports -mm-dd hh:mm:ss, we can add a new time-extractor kind 
> to support MMdd in a single partition field
> .



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] flinkbot edited a comment on pull request #17843: [FLINK-24879][core] All ReducingStateDescriptor constructor should check reduceFunction is not a richFunction.

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7145f2799d9046ab813e3d49d72019b9cffebf32 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26773)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Updated] (FLINK-11021) ZoneOffset objects don't appear to be serialized correctly

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11021:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> ZoneOffset objects don't appear to be serialized correctly
> --
>
> Key: FLINK-11021
> URL: https://issues.apache.org/jira/browse/FLINK-11021
> Project: Flink
>  Issue Type: Bug
>  Components: API / Type Serialization System
>Affects Versions: 1.6.2
> Environment: Scala 2.11.11, OpenJDK 1.8.0_192-b12
>Reporter: Christina
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
> Attachments: TimezoneStreamProcessor.scala
>
>
> In Flink 1.6.2 ZoneOffset objects are not being serialized correctly: they 
> are turned into `null` when serialized in a Flink job. I've attached a basic 
> sample job that illustrates the problem along with a few sbt console commands 
> (below) that also exhibit the problem.
>  
> {code:java}
> import org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
> import java.time._
> import java.time.temporal.ChronoUnit
> val env = StreamExecutionEnvironment.createLocalEnvironment(1)
> val UTCZoneId = ZoneId.of("UTC")
> val UTCZoneOffset = ZoneOffset.UTC
> case class MyTime(
> timestamp: ZonedDateTime,
> zoneOffset: ZoneOffset
> ) extends Serializable
> val now = MyTime(ZonedDateTime.now(UTCZoneId).truncatedTo(ChronoUnit.MILLIS), 
> UTCZoneOffset)
> val mytimeTypeInfo = 
> org.apache.flink.api.common.typeinfo.TypeInformation.of(classOf[MyTime])
> val ser = mytimeTypeInfo.createSerializer(env.getConfig)
> val out = new org.apache.flink.core.memory.ByteArrayDataOutputView()
> val serialized = ser.serialize(now, out)
> val bytes = out.toByteArray
> val in = new org.apache.flink.core.memory.ByteArrayDataInputView(bytes)
> val deserialized = ser.deserialize(in)
> println(s"""
> before serializaton: $now
> after serialization: $deserialized
> """){code}
>  



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11002) Trigger.clear() will not be called after purged window

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11002:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Trigger.clear() will not be called after purged window
> --
>
> Key: FLINK-11002
> URL: https://issues.apache.org/jira/browse/FLINK-11002
> Project: Flink
>  Issue Type: Bug
>  Components: API / DataStream
>Affects Versions: 1.6.2
>Reporter: Yuan Yifan
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> The `clear` method 
> (org.apache.flink.streaming.api.windowing.triggers.Trigger#clear) will not be 
> called while return a `TriggerResult.FIRE_AND_PURGE` in 
> onElement/onProcessingTime/onEventTime, this may cause the trigger can't 
> purge after trggered the condition.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11018) Flink ignores logback.xml

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11018:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Flink ignores logback.xml 
> --
>
> Key: FLINK-11018
> URL: https://issues.apache.org/jira/browse/FLINK-11018
> Project: Flink
>  Issue Type: Bug
>  Components: Command Line Client
>Affects Versions: 1.6.2
>Reporter: prathamesh
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
> Attachments: logback.xml
>
>
> I am running flink locally on Windows as per instructions specified in the 
> [link documentation 
> |https://ci.apache.org/projects/flink/flink-docs-stable/start/flink_on_windows.html]
> flink version: 1.6.1
> The job i am running is the Sample Job 
> ([https://ci.apache.org/projects/flink/flink-docs-release-1.6/quickstart/setup_quickstart.html#read-the-code]).
> I am also configuring a logstash appender (logstash-logback-encoder) in order 
> to send the logs to a logstash instance running locally along with console 
> and file appenders.
> When i run this flink job from my IDE, the logs are sent successfully to my 
> logstash instance. However when i submit the same job to my flink cluster, i 
> don't see any logs on logstash. Neither do i see any error indicating any 
> failure to create the logstash appender.
> I am pretty sure the logstash appender works fine since it works when i run 
> the job from IDE. As per the [link Best 
> Practices|https://ci.apache.org/projects/flink/flink-docs-stable/dev/best_practices.html],
>  Flink uses log4j by default and needs to be configured to use logback. Does 
> this apply to flink logs as in Taskmanager and jobmanager logs or to 
> application logs? 
> Is flink ignoring the logback.xml file that gets packaged in my jar? How to 
> get flink to use the logback configuration that is included in the jar?



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11034) Provide "rewriting config” to file system factory

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11034:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Provide "rewriting config” to file system factory 
> --
>
> Key: FLINK-11034
> URL: https://issues.apache.org/jira/browse/FLINK-11034
> Project: Flink
>  Issue Type: Improvement
>  Components: Connectors / FileSystem, FileSystems
>Reporter: Wei-Che Wei
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> In the discussion in this mailing thread 
> [http://apache-flink-user-mailing-list-archive.2336050.n4.nabble.com/how-to-override-s3-key-config-in-flink-job-td24606.html],
>  it showed that it is not able to overwrite config in file system factory 
> when submit a flink job.
> That means we will share the same config for multiple jobs in a session 
> cluster. Or user can't use different configuration for checkpointing and file 
> sink. For example, user might have different s3 buckets for checkpointing and 
> file sink, but each of the s3 bucket might have different s3 access key for 
> some management concerns.
> We might need to provide a way to overwrite configuration when calling file 
> system factory "get" method, and let those user facing components, like 
> checkpointing or file sink, will be able to get overwriting config from user 
> and create a file system with those changes in the new config.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11030) Cannot use Avro logical types with ConfluentRegistryAvroDeserializationSchema

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11030:
---
Labels: auto-deprioritized-major pull-request-available stale-minor  (was: 
auto-deprioritized-major pull-request-available)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Cannot use Avro logical types with ConfluentRegistryAvroDeserializationSchema
> -
>
> Key: FLINK-11030
> URL: https://issues.apache.org/jira/browse/FLINK-11030
> Project: Flink
>  Issue Type: Bug
>  Components: Formats (JSON, Avro, Parquet, ORC, SequenceFile)
>Affects Versions: 1.6.2
>Reporter: Maciej Bryński
>Priority: Minor
>  Labels: auto-deprioritized-major, pull-request-available, 
> stale-minor
>  Time Spent: 20m
>  Remaining Estimate: 0h
>
> I created Specific class for Kafka topic. 
>  Avro schema includes logicalTypes.
>  Then I want to read data using following code:
> {code:scala}
> val deserializationSchema = 
> ConfluentRegistryAvroDeserializationSchema.forSpecific(classOf[mySpecificClass],
>  schemaRegistryUrl)
> val kafkaStream = env.addSource(
>   new FlinkKafkaConsumer011(topic, deserializationSchema, kafkaProperties)
> )
> kafkaStream.print()
> {code}
>  Result:
>  {code}
>  Exception in thread "main" 
> org.apache.flink.runtime.client.JobExecutionException: 
> java.lang.ClassCastException: java.lang.Long cannot be cast to 
> org.joda.time.DateTime
>  at 
> org.apache.flink.runtime.minicluster.MiniCluster.executeJobBlocking(MiniCluster.java:623)
>  at 
> org.apache.flink.streaming.api.environment.LocalStreamEnvironment.execute(LocalStreamEnvironment.java:123)
>  at 
> org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.java:1511)
>  at 
> org.apache.flink.streaming.api.scala.StreamExecutionEnvironment.execute(StreamExecutionEnvironment.scala:645)
>  at TransactionEnrichment$.main(TransactionEnrichment.scala:50)
>  at TransactionEnrichment.main(TransactionEnrichment.scala)
>  Caused by: java.lang.ClassCastException: java.lang.Long cannot be cast to 
> org.joda.time.DateTime
>  at platform_tbl_game_transactions_v1.Value.put(Value.java:222)
>  at org.apache.avro.generic.GenericData.setField(GenericData.java:690)
>  at 
> org.apache.avro.specific.SpecificDatumReader.readField(SpecificDatumReader.java:119)
>  at 
> org.apache.avro.generic.GenericDatumReader.readRecord(GenericDatumReader.java:222)
>  at 
> org.apache.avro.generic.GenericDatumReader.readWithoutConversion(GenericDatumReader.java:175)
>  at 
> org.apache.avro.generic.GenericDatumReader.read(GenericDatumReader.java:153)
>  at 
> org.apache.avro.generic.GenericDatumReader.read(GenericDatumReader.java:145)
>  at 
> org.apache.flink.formats.avro.RegistryAvroDeserializationSchema.deserialize(RegistryAvroDeserializationSchema.java:74)
>  at 
> org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper.deserialize(KeyedDeserializationSchemaWrapper.java:44)
>  at 
> org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher.runFetchLoop(Kafka09Fetcher.java:142)
>  at 
> org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase.run(FlinkKafkaConsumerBase.java:738)
>  at 
> org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:87)
>  at 
> org.apache.flink.streaming.api.operators.StreamSource.run(StreamSource.java:56)
>  at 
> org.apache.flink.streaming.runtime.tasks.SourceStreamTask.run(SourceStreamTask.java:99)
>  at 
> org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:300)
>  at org.apache.flink.runtime.taskmanager.Task.run(Task.java:711)
>  at java.lang.Thread.run(Thread.java:748)
>  {code}
>  When using Kafka Consumer there was a hack for this to use LogicalConverters.
>  Unfortunately it's not working in flink.
>  {code}
>  SpecificData.get.addLogicalTypeConversion(new 
> TimeConversions.TimestampConversion)
>  {code}
> Problem probably is cause by the fact we're creating own instance of 
> SpecificData
> https://github.com/apache/flink/blob/master/flink-formats/flink-avro/src/main/java/org/apache/flink/formats/avro/AvroDeserializationSchema.java#L145
> And there is no logical conversions added.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-10962) Allow correlations between subtask metrics and checkpoint metrics

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-10962:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Allow correlations between subtask metrics and checkpoint metrics
> -
>
> Key: FLINK-10962
> URL: https://issues.apache.org/jira/browse/FLINK-10962
> Project: Flink
>  Issue Type: Improvement
>  Components: Runtime / Web Frontend
>Affects Versions: 1.7.0
>Reporter: Nico Kruber
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> Currently, if you click into a running job and look into the "Subtasks" tab, 
> it will show all subtasks' metrics like received/send bytes/records, host 
> name, status. If you browse into some checkpoint (in the "Checkpoints" tab), 
> it will show the checkpoint statistics (size, buffer alignment, subtask ID). 
> You cannot easily correlate the two, e.g. if you want to see whether a 
> subtask with high input load also has large state.
> I'd suggest to either add the subtask ID to the "Subtasks" view, or the 
> hostname to the checkpoint details (or both). Even better would be a direct 
> link to switch from one view to the other and preselecting a specific subtask.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15422) Expose Jvm Metaspace、Compressed Class Space、Eden Space、Survivor Space、Old Gen metric

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15422:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Expose Jvm Metaspace、Compressed Class Space、Eden Space、Survivor Space、Old Gen 
> metric
> 
>
> Key: FLINK-15422
> URL: https://issues.apache.org/jira/browse/FLINK-15422
> Project: Flink
>  Issue Type: Improvement
>  Components: Runtime / Metrics
>Reporter: lining
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> Current, we just expose JVM the metrics of heap and non-heap. But users 
> couldn't get details of JVM.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15513) Error in SQL Reserved Keywords doc

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15513:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Error in SQL Reserved Keywords doc
> --
>
> Key: FLINK-15513
> URL: https://issues.apache.org/jira/browse/FLINK-15513
> Project: Flink
>  Issue Type: Improvement
>  Components: Documentation, Table SQL / API
>Affects Versions: 1.9.1, 1.10.0
>Reporter: Zou
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> # Missing 59 keywords, such as 'ARRAY_MAX_CARDINALITY', 'PERCENT', 'PER'
>  # Including 241 non reserved keywords, such as 'ABSOLUTE', 'ADD'
> FYI: 
> [https://ci.apache.org/projects/flink/flink-docs-master/dev/table/sql/#reserved-keywords]



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11058) FlinkKafkaProducer011 fails when kafka broker crash

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11058:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> FlinkKafkaProducer011 fails when kafka broker crash
> ---
>
> Key: FLINK-11058
> URL: https://issues.apache.org/jira/browse/FLINK-11058
> Project: Flink
>  Issue Type: Bug
>  Components: Connectors / Kafka
>Affects Versions: 1.6.2
> Environment: flink version:1.6.0
>  
>Reporter: cz
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> Caused by: 
> org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException: 
> Could not forward element to next operator
>  at 
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.pushToOperator(OperatorChain.java:596)
>  at 
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:554)
>  at 
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.collect(OperatorChain.java:534)
>  at 
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:689)
>  at 
> org.apache.flink.streaming.api.operators.AbstractStreamOperator$CountingOutput.collect(AbstractStreamOperator.java:667)
>  at 
> org.apache.flink.streaming.api.operators.StreamMap.processElement(StreamMap.java:41)
>  at 
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.pushToOperator(OperatorChain.java:579)
>  ... 14 more
> Caused by: 
> org.apache.flink.streaming.connectors.kafka.FlinkKafka011Exception: Failed to 
> send data to Kafka: Expiring 1 record(s) for topic-5: 30091 ms has passed 
> since batch creation plus linger time
>  at 
> org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.checkErroneous(FlinkKafkaProducer011.java:1010)
>  at 
> org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.invoke(FlinkKafkaProducer011.java:614)
>  at 
> org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer011.invoke(FlinkKafkaProducer011.java:93)
>  at 
> org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction.invoke(TwoPhaseCommitSinkFunction.java:219)
>  at 
> org.apache.flink.streaming.api.operators.StreamSink.processElement(StreamSink.java:56)
>  at 
> org.apache.flink.streaming.runtime.tasks.OperatorChain$CopyingChainingOutput.pushToOperator(OperatorChain.java:579)
>  ... 20 more
> Caused by: org.apache.kafka.common.errors.TimeoutException: Expiring 1 
> record(s) for sec-yrdun-fwalarm-topic-5: 30091 ms has passed since batch 
> creation plus linger time



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11050) When IntervalJoin, get left or right buffer's entries more quickly by assigning lowerBound

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11050:
---
Labels: auto-deprioritized-major performance pull-request-available 
stale-minor  (was: auto-deprioritized-major performance pull-request-available)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> When IntervalJoin, get left or right buffer's entries more quickly by 
> assigning lowerBound
> --
>
> Key: FLINK-11050
> URL: https://issues.apache.org/jira/browse/FLINK-11050
> Project: Flink
>  Issue Type: Improvement
>  Components: Runtime / State Backends
>Affects Versions: 1.6.2, 1.7.0
>Reporter: Liu
>Priority: Minor
>  Labels: auto-deprioritized-major, performance, 
> pull-request-available, stale-minor
>  Time Spent: 10m
>  Remaining Estimate: 0h
>
>     When IntervalJoin, it is very slow to get left or right buffer's entries. 
> Because we have to scan all buffer's values, including the deleted values 
> which are out of time range. These deleted values's processing consumes too 
> much time in RocksDB's level 0. Since lowerBound is known, it can be 
> optimized by seek from the timestamp of lowerBound.
>     Our usage is like below:
> {code:java}
> labelStream.keyBy(uuid).intervalJoin(adLogStream.keyBy(uuid))
>.between(Time.milliseconds(0), Time.milliseconds(60))
>.process(new processFunction())
>.sink(kafkaProducer)
> {code}
>     Our data is huge. The job always runs for an hour and is stuck by 
> RocksDB's seek when get buffer's entries. We use rocksDB's data to simulate 
> the problem RocksDB and find that it takes too much time in deleted values. 
> So we decide to optimize it by assigning the lowerBound instead of global 
> search.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-10989) OrcRowInputFormat uses two different file systems

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-10989:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> OrcRowInputFormat uses two different file systems
> -
>
> Key: FLINK-10989
> URL: https://issues.apache.org/jira/browse/FLINK-10989
> Project: Flink
>  Issue Type: Bug
>  Components: Connectors / ORC
>Affects Versions: 1.7.0
>Reporter: Till Rohrmann
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> The {{OrcRowInputFormat}} seems to use two different {{FileSystem}}. The 
> Flink {{FileSystem}} for listing the files and generating the {{InputSplits}} 
> and then Hadoop's {{FileSystem}} to actually read the input splits. This can 
> be problematic if one only configures Flink's S3 {{FileSystem}} but does not 
> provide a S3 implementation for Hadoop's {{FileSystem}}.
> I think this is not an intuitive behaviour and can lead to hard to debug 
> problems for a user.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-11038) Rewrite Kafka at-least-once it cases

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-11038:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Rewrite Kafka at-least-once it cases
> 
>
> Key: FLINK-11038
> URL: https://issues.apache.org/jira/browse/FLINK-11038
> Project: Flink
>  Issue Type: Bug
>  Components: Connectors / Kafka
>Affects Versions: 1.7.0
>Reporter: Piotr Nowojski
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> Currently they are using {{NetworkFailuresProxy}} which is unstable both for 
> Kafka 0.11 in exactly once mode (in 50% tests are live locking) and for Kafka 
> 2.0 (and because of that currently {{testOneToOneAtLeastOnceRegularSink}} and 
> {{testOneToOneAtLeastOnceCustomOperator}} tests are disabled).
> Those tests should either be rewritten to SIGKILL Flink's process doing the 
> writing. Either as an ITCase SIGKILL-ing task manager or test harness 
> SIGKILL-ing/exiting test harness process.
> We can not simply use test harness and do not close it to simulate failure, 
> because we want to make sure that we have flushed the records during 
> checkpoint. If we do not SIGKILL the process, the background Kafka client's 
> threads can just send those records for us.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-10988) Improve debugging / visibility of job state

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-10988:
---
Labels: auto-deprioritized-major stale-minor  (was: 
auto-deprioritized-major)

I am the [Flink Jira Bot|https://github.com/apache/flink-jira-bot/] and I help 
the community manage its development. I see this issues has been marked as 
Minor but is unassigned and neither itself nor its Sub-Tasks have been updated 
for 180 days. I have gone ahead and marked it "stale-minor". If this ticket is 
still Minor, please either assign yourself or give an update. Afterwards, 
please remove the label or in 7 days the issue will be deprioritized.


> Improve debugging / visibility of job state
> ---
>
> Key: FLINK-10988
> URL: https://issues.apache.org/jira/browse/FLINK-10988
> Project: Flink
>  Issue Type: Improvement
>  Components: Runtime / Task
>Reporter: Scott Sue
>Priority: Minor
>  Labels: auto-deprioritized-major, stale-minor
>
> When a Flink Job is running and encounters an unexpected exception, either 
> through processing an expected message, or a message that may be well formed, 
> but the state of the job renders a exception.  It can be difficult to 
> diagnose the cause of the issue.  For example I would get a NPE in one of the 
> Operators:
> 2018-11-13 10:10:26,332 INFO 
> org.apache.flink.runtime.executiongraph.ExecutionGraph - 
> Co-Process-Broadcast-Keyed -> Map -> Map -> Sin
> k: Unnamed (1/1) (9a8f3b970570742b7b174a01a9bb1405) switched from RUNNING to 
> FAILED.
> java.lang.NullPointerException
>  at 
> com.celertech.analytics.flink.topology.marketimpact.PriceUtils.findPriceForEntryType(PriceUtils.java:28)
>  at 
> com.celertech.analytics.flink.topology.marketimpact.PriceUtils.getPriceForMarketDataEntryType(PriceUtils.java:18)
>  at 
> com.celertech.analytics.flink.function.midrate.MidRateBroadcaster.processBroadcastElement(MidRateBroadcaster.java:77)
>  at 
> com.celertech.analytics.flink.function.midrate.MidRateTagKeyedBroadcastProcessFunction.processBroadcastElement(MidRateTagKeyedBroa
> dcastProcessFunction.java:36)
>  at 
> com.celertech.analytics.flink.function.midrate.MidRateTagKeyedBroadcastProcessFunction.processBroadcastElement(MidRateTagKeyedBroa
> dcastProcessFunction.java:12)
>  at 
> org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator.processElement2(CoBroadcastWithKeyedOperator.java:121)
>  
> An improvement to this would be to allow the printing of the incoming message 
> so the developer can diagnose if that message was correct.  Printing of the 
> state of the job would be nice as well just in case the state of the job was 
> incorrect leading to the exception
>  



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15433) flink-hbase add kerberos support

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15433:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> flink-hbase add kerberos support
> 
>
> Key: FLINK-15433
> URL: https://issues.apache.org/jira/browse/FLINK-15433
> Project: Flink
>  Issue Type: Improvement
>  Components: Connectors / HBase
>Reporter: xiaodao
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> hbase opened kerberos is Common scenarios , we can add support to hbase which 
> is opened with kerberos.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15633) Javadocs cannot be built on Java 11

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15633:
---
  Labels: auto-deprioritized-minor pull-request-available  (was: 
pull-request-available stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Javadocs cannot be built on Java 11
> ---
>
> Key: FLINK-15633
> URL: https://issues.apache.org/jira/browse/FLINK-15633
> Project: Flink
>  Issue Type: Bug
>  Components: Build System, Release System
>Affects Versions: 1.10.0
>Reporter: Chesnay Schepler
>Priority: Not a Priority
>  Labels: auto-deprioritized-minor, pull-request-available
>  Time Spent: 20m
>  Remaining Estimate: 0h
>
> The javadoc-plugin fails when run Java 11. This isn't a big issue since we do 
> our releases on JDK 8 anyway, but we should still fix it so users can 
> reproduce releases on JDK 11.
> {code}
> java.lang.ExceptionInInitializerError
>   at 
> org.apache.maven.plugin.javadoc.AbstractJavadocMojo.(AbstractJavadocMojo.java:190)
>   at 
> java.base/jdk.internal.reflect.NativeConstructorAccessorImpl.newInstance0(Native
>  Method)
>   at 
> java.base/jdk.internal.reflect.NativeConstructorAccessorImpl.newInstance(NativeConstructorAccessorImpl.java:62)
>   at 
> java.base/jdk.internal.reflect.DelegatingConstructorAccessorImpl.newInstance(DelegatingConstructorAccessorImpl.java:45)
>   at 
> java.base/java.lang.reflect.Constructor.newInstance(Constructor.java:488)
>   at 
> com.google.inject.internal.DefaultConstructionProxyFactory$1.newInstance(DefaultConstructionProxyFactory.java:86)
>   at 
> com.google.inject.internal.ConstructorInjector.provision(ConstructorInjector.java:105)
>   at 
> com.google.inject.internal.ConstructorInjector.access$000(ConstructorInjector.java:32)
>   at 
> com.google.inject.internal.ConstructorInjector$1.call(ConstructorInjector.java:89)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback$Provision.provision(ProvisionListenerStackCallback.java:115)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback$Provision.provision(ProvisionListenerStackCallback.java:133)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback.provision(ProvisionListenerStackCallback.java:68)
>   at 
> com.google.inject.internal.ConstructorInjector.construct(ConstructorInjector.java:87)
>   at 
> com.google.inject.internal.ConstructorBindingImpl$Factory.get(ConstructorBindingImpl.java:267)
>   at 
> com.google.inject.internal.InjectorImpl$2$1.call(InjectorImpl.java:1016)
>   at 
> com.google.inject.internal.InjectorImpl.callInContext(InjectorImpl.java:1103)
>   at com.google.inject.internal.InjectorImpl$2.get(InjectorImpl.java:1012)
>   at 
> com.google.inject.internal.InjectorImpl.getInstance(InjectorImpl.java:1051)
>   at 
> org.eclipse.sisu.space.AbstractDeferredClass.get(AbstractDeferredClass.java:48)
>   at 
> com.google.inject.internal.ProviderInternalFactory.provision(ProviderInternalFactory.java:81)
>   at 
> com.google.inject.internal.InternalFactoryToInitializableAdapter.provision(InternalFactoryToInitializableAdapter.java:53)
>   at 
> com.google.inject.internal.ProviderInternalFactory$1.call(ProviderInternalFactory.java:65)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback$Provision.provision(ProvisionListenerStackCallback.java:115)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback$Provision.provision(ProvisionListenerStackCallback.java:133)
>   at 
> com.google.inject.internal.ProvisionListenerStackCallback.provision(ProvisionListenerStackCallback.java:68)
>   at 
> com.google.inject.internal.ProviderInternalFactory.circularGet(ProviderInternalFactory.java:63)
>   at 
> com.google.inject.internal.InternalFactoryToInitializableAdapter.get(InternalFactoryToInitializableAdapter.java:45)
>   at 
> com.google.inject.internal.InjectorImpl$2$1.call(InjectorImpl.java:1016)
>   at 
> com.google.inject.internal.InjectorImpl.callInContext(InjectorImpl.java:1092)
>   at com.google.inject.internal.InjectorImpl$2.get(InjectorImpl.java:1012)
>   at org.eclipse.sisu.inject.Guice4$1.get(Guice4.java:162)
>   at org.eclipse.sisu.inject.LazyBeanEntry.getValue(LazyBeanEntry.java:81)
>   at 
> org.eclipse.sisu.plexus.LazyPlexusBean.getValue(LazyPlexusBean.java:51)
>   at 
> org.codehaus.plexus.DefaultPlexusContainer.lookup(DefaultPlexusContainer.java:263)
>   at 
> org.codehaus.plexus.DefaultPlex

[jira] [Updated] (FLINK-15622) Clarify plugin mechanism in documentation

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15622:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Clarify plugin mechanism in documentation
> -
>
> Key: FLINK-15622
> URL: https://issues.apache.org/jira/browse/FLINK-15622
> Project: Flink
>  Issue Type: Improvement
>  Components: Documentation, FileSystems
>Reporter: Seth Wiesman
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> The flink documentation has passing references to the new plugin architecture 
> released in Flink 1.9 but nothing concrete. It is not immediately clear:
> 1) What a plugin is
> 2) How it affects the bundling of dependencies



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15634) disableAutoGeneratedUIDs fails with coGroup and join

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15634:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> disableAutoGeneratedUIDs fails with coGroup and join
> 
>
> Key: FLINK-15634
> URL: https://issues.apache.org/jira/browse/FLINK-15634
> Project: Flink
>  Issue Type: Bug
>  Components: API / DataStream
>Affects Versions: 1.10.0
>Reporter: Jürgen Kreileder
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> coGroup/join seems to generate two Map operators for which you can't set the 
> UID. 
> Here's a test case:
> {code:java}
> @Test
> public void testDisablingAutoUidsWorksWithCoGroup() throws Exception {
>StreamExecutionEnvironment env = 
> StreamExecutionEnvironment.getExecutionEnvironment();
>env.getConfig().disableAutoGeneratedUIDs();
>env
>   .addSource(new 
> NoOpSourceFunction()).setUidHash("")
>   .coGroup(env.addSource(new 
> NoOpSourceFunction()).setUidHash(""))
>   .where(o -> o).equalTo(o -> o)
>   .window(TumblingEventTimeWindows.of(Time.days(1)))
>   .with(new CoGroupFunction() {
>  @Override
>  public void coGroup(Iterable first, Iterable second, 
> Collector out) throws Exception {
>  }
>   }).setUidHash("")
>   .addSink(new 
> DiscardingSink<>()).setUidHash("");
>env.execute();
> }
> {code}
>  



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15569) Incorrect sample code in udf document

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15569:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Incorrect sample code in udf document
> -
>
> Key: FLINK-15569
> URL: https://issues.apache.org/jira/browse/FLINK-15569
> Project: Flink
>  Issue Type: Improvement
>  Components: Documentation
>Affects Versions: 1.10.0
>Reporter: Jeff Zhang
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
> Attachments: image-2020-01-13-16-59-00-022.png
>
>
> Should use JTuple2 instead of JTuple1
>  !image-2020-01-13-16-59-00-022.png! 



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15644) Add support for SQL query validation

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15644:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Add support for SQL query validation 
> -
>
> Key: FLINK-15644
> URL: https://issues.apache.org/jira/browse/FLINK-15644
> Project: Flink
>  Issue Type: New Feature
>  Components: Table SQL / API
>Reporter: Fabian Hueske
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> It would be good if the {{TableEnvironment}} would offer methods to check the 
> validity of SQL queries. Such a method could be used by services (CLI query 
> shells, notebooks, SQL UIs) that are backed by Flink and execute their 
> queries on Flink.
> Validation should be available in two levels:
>  # Validation of syntax and semantics: This includes parsing the query, 
> checking the catalog for dbs, tables, fields, type checks for expressions and 
> functions, etc. This will check if the query is a valid SQL query.
>  # Validation that query is supported: Checks if Flink can execute the given 
> query. Some syntactically and semantically valid SQL queries are not 
> supported, esp. in a streaming context. This requires running the optimizer. 
> If the optimizer generates an execution plan, the query can be executed. This 
> check includes the first step and is more expensive.
> The reason for this separation is that the first check can be done much fast 
> as it does not involve calling the optimizer. Hence, it would be suitable for 
> fast checks in an interactive query editor. The second check might take more 
> time (depending on the complexity of the query) and might not be suitable for 
> rapid checks but only on explicit user request.
> Requirements:
>  * validation does not modify the state of the {{TableEnvironment}}, i.e. it 
> does not add plan operators
>  * validation does not require connector dependencies
>  * validation can identify the update mode of a continuous query result 
> (append-only, upsert, retraction).
> Out of scope for this issue:
>  * better error messages for unsupported features as suggested by FLINK-7217



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15663) Kerberos Support in Kubernetes mode

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15663:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Kerberos Support in Kubernetes mode
> ---
>
> Key: FLINK-15663
> URL: https://issues.apache.org/jira/browse/FLINK-15663
> Project: Flink
>  Issue Type: New Feature
>  Components: Deployment / Kubernetes
>Reporter: Canbin Zheng
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
>
> This is the umbrella issue for all Kerberos related tasks with relation to 
> Flink on Kubernetes.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[jira] [Updated] (FLINK-15664) Flink plan visualizer does not show operators information completely when there are line wrap

2021-11-19 Thread Flink Jira Bot (Jira)


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

Flink Jira Bot updated FLINK-15664:
---
  Labels: auto-deprioritized-major auto-deprioritized-minor  (was: 
auto-deprioritized-major stale-minor)
Priority: Not a Priority  (was: Minor)

This issue was labeled "stale-minor" 7 days ago and has not received any 
updates so it is being deprioritized. If this ticket is actually Minor, please 
raise the priority and ask a committer to assign you the issue or revive the 
public discussion.


> Flink plan visualizer does not show operators information completely when 
> there are line wrap
> -
>
> Key: FLINK-15664
> URL: https://issues.apache.org/jira/browse/FLINK-15664
> Project: Flink
>  Issue Type: Bug
>  Components: Project Website
>Affects Versions: 1.9.0, 1.9.1, 1.10.0
>Reporter: Yun Gao
>Priority: Not a Priority
>  Labels: auto-deprioritized-major, auto-deprioritized-minor
> Attachments: bad_display.png, bad_display.txt
>
>
> When there are line wrap in the diagram created by ([flink plan 
> visualizer|[https://flink.apache.org/visualizer/]]), the operator information 
> will not be shown completely, as shown in the attached image.
>  



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] flinkbot edited a comment on pull request #17844: [FLINK-24925] [core] SingleThreadAccessCheckingTypeSerializer#equals() compares different data type.

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 3375518299dfe28beb558a4a1088c6cdd297b7ee Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26778)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot commented on pull request #17844: [FLINK-24925] [core] SingleThreadAccessCheckingTypeSerializer#equals() compares different data type.

2021-11-19 Thread GitBox


flinkbot commented on pull request #17844:
URL: https://github.com/apache/flink/pull/17844#issuecomment-974513277


   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 3375518299dfe28beb558a4a1088c6cdd297b7ee (Fri Nov 19 
22:25:43 UTC 2021)
   
   **Warnings:**
* No documentation files were touched! Remember to keep the Flink docs up 
to date!
* **This pull request references an unassigned [Jira 
ticket](https://issues.apache.org/jira/browse/FLINK-24925).** According to the 
[code contribution 
guide](https://flink.apache.org/contributing/contribute-code.html), tickets 
need to be assigned before starting with the implementation work.
   
   
   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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot commented on pull request #17844: [FLINK-24925] [core] SingleThreadAccessCheckingTypeSerializer#equals() compares different data type.

2021-11-19 Thread GitBox


flinkbot commented on pull request #17844:
URL: https://github.com/apache/flink/pull/17844#issuecomment-974512248


   
   ## CI report:
   
   * 3375518299dfe28beb558a4a1088c6cdd297b7ee UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[jira] [Updated] (FLINK-24925) SingleThreadAccessCheckingTypeSerializer#equals() evaluates wrong field.

2021-11-19 Thread ASF GitHub Bot (Jira)


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

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

> SingleThreadAccessCheckingTypeSerializer#equals() evaluates wrong field.
> 
>
> Key: FLINK-24925
> URL: https://issues.apache.org/jira/browse/FLINK-24925
> Project: Flink
>  Issue Type: Bug
>Reporter: bx123
>Priority: Minor
>  Labels: pull-request-available
>
> In equals(), we should compare this.originalSerializer with 
> obj.originalSerializer rather than obj itself. Otherwise current 
> implementation will always return false. 
> BTW, It seems this method not really used and this class is used only in 
> tests. 



--
This message was sent by Atlassian Jira
(v8.20.1#820001)


[GitHub] [flink] gmzz123 opened a new pull request #17844: [FLINK-24925] [core] SingleThreadAccessCheckingTypeSerializer#equals() compares different data type.

2021-11-19 Thread GitBox


gmzz123 opened a new pull request #17844:
URL: https://github.com/apache/flink/pull/17844


   
   
   ## What is the purpose of the change
   
   In equals(), we should compare this.originalSerializer with 
obj.originalSerializer rather than obj itself. Otherwise current implementation 
will always return false. 
   
   ## Brief change log
   
   change to compare the right field.
   
   ## Verifying this change
   
   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, ZooKeeper: (no)
 - The S3 file system connector: (no)
   
   ## Documentation
   
 - Does this pull request introduce a new feature? (no)
 - If yes, how is the feature documented? (not applicable / docs / JavaDocs 
/ not documented)
   


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

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * c98fd993da90322dc9fb6e292b3a964726302a44 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26772)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[CANCELED](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * c98fd993da90322dc9fb6e292b3a964726302a44 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26772)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17843: [FLINK-24879][core] All ReducingStateDescriptor constructor should check reduceFunction is not a richFunction.

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7145f2799d9046ab813e3d49d72019b9cffebf32 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26773)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot commented on pull request #17843: [FLINK-24879][core] All ReducingStateDescriptor constructor should check reduceFunction is not a richFunction.

2021-11-19 Thread GitBox


flinkbot commented on pull request #17843:
URL: https://github.com/apache/flink/pull/17843#issuecomment-974464229


   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 7145f2799d9046ab813e3d49d72019b9cffebf32 (Fri Nov 19 
20:52:07 UTC 2021)
   
   **Warnings:**
* No documentation files were touched! Remember to keep the Flink docs up 
to date!
* **This pull request references an unassigned [Jira 
ticket](https://issues.apache.org/jira/browse/FLINK-24879).** According to the 
[code contribution 
guide](https://flink.apache.org/contributing/contribute-code.html), tickets 
need to be assigned before starting with the implementation work.
   
   
   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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot commented on pull request #17843: [FLINK-24879][core] All ReducingStateDescriptor constructor should check reduceFunction is not a richFunction.

2021-11-19 Thread GitBox


flinkbot commented on pull request #17843:
URL: https://github.com/apache/flink/pull/17843#issuecomment-974462738


   
   ## CI report:
   
   * 7145f2799d9046ab813e3d49d72019b9cffebf32 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] gmzz123 opened a new pull request #17843: [FLINK-24879][core] All ReducingStateDescriptor constructor should check reduceFunction is not a richFunction.

2021-11-19 Thread GitBox


gmzz123 opened a new pull request #17843:
URL: https://github.com/apache/flink/pull/17843


   
   
   ## What is the purpose of the change
   
   All the constructor should check reduceFunction is not a richFunction, not 
just when passing typeClass as parameter.
   
   ## Brief change log
   
   extract a function to check the reduceFunction and call it in all 
constructors.
   
   ## Verifying this change
   
   This change is a trivial rework / code cleanup.
   
   add test to check the Type is Type.REDUCING.
   
   ## 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, ZooKeeper: (no)
 - The S3 file system connector: (no)
   
   ## Documentation
   
 - Does this pull request introduce a new feature? (no)
 - If yes, how is the feature documented? (not applicable / docs / JavaDocs 
/ not documented)
   


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

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17800: [FLINK-24781] Add to string casting rules

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 10856191a880a04a242bd69e19a657d7c5b9ef4b Azure: 
[SUCCESS](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26768)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * c98fd993da90322dc9fb6e292b3a964726302a44 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26772)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * c98fd993da90322dc9fb6e292b3a964726302a44 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * c98fd993da90322dc9fb6e292b3a964726302a44 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * a36baca3e39515fe6531a78c263ce7e080069192 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * a36baca3e39515fe6531a78c263ce7e080069192 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26771)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26771)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * a36baca3e39515fe6531a78c263ce7e080069192 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * a36baca3e39515fe6531a78c263ce7e080069192 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * a36baca3e39515fe6531a78c263ce7e080069192 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * 8162ba5e226479e68dd3615a874f6ba98baafe34 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   * c847ce6f383ebe2588f1ca020b0865ba226d1dd5 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17842: [FLINK-24966] [docs] Fix spelling errors in the project

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 7ab93fde650e491e1f2f00a3237cb8f4b250eb85 Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26769)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17800: [FLINK-24781] Add to string casting rules

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * b854a72738520eced2579220fd9770412f87f354 Azure: 
[CANCELED](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26765)
 
   * 10856191a880a04a242bd69e19a657d7c5b9ef4b Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26768)
 
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




[GitHub] [flink] flinkbot edited a comment on pull request #17811: [FLINK-24754] Implement CHAR/VARCHAR length validation for sinks

2021-11-19 Thread GitBox


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


   
   ## CI report:
   
   * 2b885bb3d72eb7489b8aa3211d63a7c1b7ca591d Azure: 
[FAILURE](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26682)
 
   * 06a4d645f8a94bbaa756481572d94d992b4f4bc6 Azure: 
[PENDING](https://dev.azure.com/apache-flink/98463496-1af2-4620-8eab-a2ecc1a2e6fe/_build/results?buildId=26770)
 
   * 8162ba5e226479e68dd3615a874f6ba98baafe34 UNKNOWN
   
   
   Bot commands
 The @flinkbot bot supports the following commands:
   
- `@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.

To unsubscribe, e-mail: issues-unsubscr...@flink.apache.org

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




  1   2   3   4   5   >