Re: [ANNOUNCE] Flink Table Store Joins Apache Incubator as Apache Paimon(incubating)

2023-03-28 Thread Guowei Ma
Congratulations! Best, Guowei On Tue, Mar 28, 2023 at 12:02 PM Yuxin Tan wrote: > Congratulations! > > Best, > Yuxin > > > Guanghui Zhang 于2023年3月28日周二 11:06写道: > >> Congratulations! >> >> Best, >> Zhang Guanghui >> >> Hang Ruan 于2023年3月28日周二 10:29写道: >> >> > Congratulations! >> > >> >

Re: [ANNOUNCE] Flink Table Store Joins Apache Incubator as Apache Paimon(incubating)

2023-03-28 Thread Guowei Ma
Congratulations! Best, Guowei On Tue, Mar 28, 2023 at 12:02 PM Yuxin Tan wrote: > Congratulations! > > Best, > Yuxin > > > Guanghui Zhang 于2023年3月28日周二 11:06写道: > >> Congratulations! >> >> Best, >> Zhang Guanghui >> >> Hang Ruan 于2023年3月28日周二 10:29写道: >> >> > Congratulations! >> > >> >

Re: Broadcast State + Stateful Operator + Async IO

2022-04-29 Thread Guowei Ma
astProcessFunction but if there's a way to avoid that also > while also ensuring ordered processing of events, then do let me know. > > On Fri, Apr 29, 2022 at 7:35 AM Guowei Ma wrote: > >> Hi Vishal >> >> I want to understand your needs first. Your requirements are: Afte

Re: Broadcast State + Stateful Operator + Async IO

2022-04-28 Thread Guowei Ma
Hi Vishal I want to understand your needs first. Your requirements are: After a stateful operator receives a notification, it needs to traverse all the data stored in the operator state, communicate with an external system during the traversal process (maybe similar to join?). In order to improve

Re: Checkpoint Timeout Troubleshooting

2022-04-28 Thread Guowei Ma
Hi Sam I think the first step is to see which part of your Flink APP is blocking the completion of Checkpoint. Specifically, you can refer to the "Checkpoint Details" section of the document [1]. Using these methods, you should be able to observe where the checkpoint is blocked, for example, it

Re: Write to Aliyun OSS via FileSystem connector hang Job Master on Finishing

2022-04-25 Thread Guowei Ma
Hi Afaik the commit files action happens at the committer operator instead of the JM size after the new sink api [1]. It means this would not happen if you use the new `FlinkSink`.[2] [1] https://cwiki.apache.org/confluence/display/FLINK/FLIP-143%3A+Unified+Sink+API [2]

Re: Handling non-transient exceptions

2022-04-19 Thread Guowei Ma
might cause irreparable damage > to applications but it could be configured per exception. > > > > > > Regards, > > José Brandão > > > > *From: *Guowei Ma > *Date: *Friday, 15 April 2022 at 11:04 > *To: *Jose Brandao > *Cc: *user@flink.apache.org > *Subj

Re: Handling non-transient exceptions

2022-04-15 Thread Guowei Ma
Hi, Jose I assume you are using the DataStream API. In general for any udf's exception in the DataStream job, only the developer of the DataStream job knows whether the exception can be tolerated. Because in some cases, tolerating exceptions can cause errors in the final result. So you still

Re: Issue with doing filesink to HDFS

2022-04-13 Thread Guowei Ma
gt; > 13/04/22, > 13:46:13 > > On Wed, Apr 13, 2022 at 1:23 PM Guowei Ma wrote: > >> Hi >> I think you need to export HADOOP_CLASSPATH correclty. [1] >> >> [1] >> https://nightlies.apache.org/flink/flink-docs-release-1.14/docs/deployment/resource-

Re: Issue with doing filesink to HDFS

2022-04-13 Thread Guowei Ma
Hi I think you need to export HADOOP_CLASSPATH correclty. [1] [1] https://nightlies.apache.org/flink/flink-docs-release-1.14/docs/deployment/resource-providers/yarn/#preparation Best, Guowei On Wed, Apr 13, 2022 at 12:50 PM Anubhav Nanda wrote: > Hi, > > I have setup flink 1.13.5 and we are

Re: Why first op after union cannot be chained?

2022-04-06 Thread Guowei Ma
Hi Zhanghao AFAIK, you might to see the `StreamingJobGraphGenerator` not the `JobGraphGenerator` which is only used by the old flink stream sql stack. >From comment of the `StreamingJobGraphGenerator::isChainableInput` the `an union operator` does not support chain currently. Best, Guowei On

Re: Is it possible to make SideOutput back to input stream?

2022-03-21 Thread Guowei Ma
Hi, Huang >From the document[1] it seems that you need to close the iterate stream. such as `iteration.closeWith(feedback);` BTW You also could get a detailed iteration example from here [2]. [1]

Re: exception when parallelizing application

2022-03-21 Thread Guowei Ma
It seems that the key's hashcode is not stable. So would you like to show the details of the `TraceKeyOuterClass.TraceKey`. Best, Guowei On Sun, Mar 20, 2022 at 3:21 PM Prashant Deva wrote: > here is the key code (in kotlin) > > val ks = object: KeySelector

Re: Controlling group partitioning with DataStream

2022-03-08 Thread Guowei Ma
Hi, Ken If you are talking about the Batch scene, there may be another idea that the engine automatically and evenly distributes the amount of data to be processed by each Stage to each worker node. This also means that, in some cases, the user does not need to manually define a Partitioner. At

Re: CSV join in batch mode

2022-02-23 Thread Guowei Ma
Hi, Killian Sorry for responding late! I think there is no simple way that could catch csv processing errors. That means that you need to do it yourself.(Correct me if I am missing something). I think you could use RockDB State Backend[1], which would spill data to disk. [1]

Re: Pulsar connector 2.9.1 failing job submission in standalone.

2022-02-21 Thread Guowei Ma
> both 2.8.0 pulsar and 2.9.1 pulsar) > > > > Regards, > > Ananth > > > > *From: *Guowei Ma > *Date: *Monday, 21 February 2022 at 4:57 pm > *To: *Ananth Gundabattula > *Cc: *user@flink.apache.org > *Subject: *Re: Pulsar connector 2.9.1 failing job submissi

Re: Apache Flink - Continuously streaming data using jdbc connector

2022-02-20 Thread Guowei Ma
Hi, You can try flink's cdc connector [1] to see if it meets your needs. [1] https://github.com/ververica/flink-cdc-connectors Best, Guowei On Mon, Feb 21, 2022 at 6:23 AM M Singh wrote: > Hi Folks: > > I am trying to monitor a jdbc source and continuously streaming data in an > application

Re: Pulsar connector 2.9.1 failing job submission in standalone.

2022-02-20 Thread Guowei Ma
Hi, Ansanth I don't see any error logs on the server side, so it's hard to tell what the specific problem is. From the current log, there are two things to try first: 1. From the client's log, it is a 5-minute timeout, so you can telnet 127.0.0.1:8086 to see if there is a problem with the local

Re: How to get FileName when using FileSink in Flink

2022-01-30 Thread Guowei Ma
Hi,Kartik FileSink does not expose the file name to the user now. Would you like to share your scenario ,which needs the file name? Best, Guowei 发自我的iPhone > 在 2022年1月30日,下午6:38,Kartik Khare 写道: > > Hi, > For my use case, I want to get the part file name that is being created in > the

Re: create savepoint on bounded source in streaming mode

2022-01-26 Thread Guowei Ma
Hi, Shawn Thank you for your sharing. Unfortunately I do not think there is an easy way to achieve this now. Actually we have a customer who has the same requirement but the scenario is a little different. The bounded and unbounded pipeline have some differences but the customer wants reuse some

Re: create savepoint on bounded source in streaming mode

2022-01-26 Thread Guowei Ma
Hi,Shawn You want to use the correct state(n-1) for day n-1 and the full amount of data for day n to produce the correct state(n) for day n. Then use state(n) to initialize a job to process the data for day n+1. Am I understanding this correctly? Best, Guowei Shawn Du 于2022年1月26日 周三下午7:15写道:

Re: create savepoint on bounded source in streaming mode

2022-01-25 Thread Guowei Ma
Hi Shawn Currently Flink can not trigger the sp at the end of the input. An alternative way might be that you need to develop a customized source, which triggers a savepoint when it notices that all the input split has been handled. Or you could see the state process api[1], which might be

Re: create savepoint on bounded source in streaming mode

2022-01-25 Thread Guowei Ma
Hi, Shawn I think Flink does not support this mechanism yet. Would you like to share the scenario in which you need this savepoint at the end of the bounded input? Best, Guowei On Wed, Jan 26, 2022 at 1:50 PM Shawn Du wrote: > Hi experts, > > assume I have several files and I want replay these

Re: Tuning akka.ask.timeout

2022-01-24 Thread Guowei Ma
; I noticed that jobmanager have a very hight CPU usage at the moment, like > 2000%. I’m reasoning about the cause by profiling. > > Best, > Paul Lam > > 2022年1月21日 09:56,Guowei Ma 写道: > > Hi, Paul > > Would you like to share some information such as the Flink versio

Re: FileSource Usage

2022-01-20 Thread Guowei Ma
new ones. Would > you know how I can enforce a reading order here ? > > Thanks, > Meghajit > > > > > On Thu, Jan 20, 2022 at 2:29 PM Guowei Ma wrote: > >> Hi, Meghajit >> >> 1. From the implementation [1] the order of split depends on the >> implem

Re: Tuning akka.ask.timeout

2022-01-20 Thread Guowei Ma
Hi, Paul Would you like to share some information such as the Flink version you used and the memory of TM and JM. And when does the timeout happen? Such as at begin of the job or during the running of the job Best, Guowei On Thu, Jan 20, 2022 at 4:45 PM Paul Lam wrote: > Hi, > > I’m tuning a

Re: FileSource Usage

2022-01-20 Thread Guowei Ma
Hi, Meghajit 1. From the implementation [1] the order of split depends on the implementation of the FileSystem. 2. From the implementation [2] the order of the file also depends on the implementation of the FileSystem. 3. Currently there is no such public interface ,which you could extend to

Re: Prom Pushgateway Reporter HTTPS support

2022-01-18 Thread Guowei Ma
Hi,Mason I assign the jira to you. Thanks for your contribution. Best, Guowei On Wed, Jan 19, 2022 at 2:07 PM Mason Chen wrote: > Hi all, > > There is some interest from our users to use prometheus push gateway > reporter with a https endpoint. So, I've filed >

Re: How does Flink add third-party jars without the service going offline

2022-01-18 Thread Guowei Ma
Hi, summer >>>Now I need to use a third-party jar in the Flink service, should I put it under ${FLINK_HOME}/lib? I think maybe an alternative way is to put the third-party jar into a fat jar. >>>How to enable Flink to automatically load third-party jars? In general this is the JVM mechanism. It

Re: mutual authentication with ssl

2021-11-25 Thread Guowei Ma
Hi Rahul >From your description I guess maybe you could try different flink.yaml(one for server and another for client). I am not an expert about SSL and security stuff. So please correct me if I am wrong. Best, Guowei On Wed, Nov 24, 2021 at 3:54 AM Rahul wrote: > Hello, > I am trying to

Re: Wrapping a GenericRecord in a Tuple

2021-11-25 Thread Guowei Ma
Hi Joseph Would you like to give more details about the error message? Best, Guowei On Thu, Nov 25, 2021 at 2:59 AM Joseph Lorenzini wrote: > Hi all, > > > > I have an implementation of KafkaDeserializationSchema interface that > deserializes a kafka consumer record into a generic record. > >

Re: What is Could not retrieve file from transient blob store?

2021-11-04 Thread Guowei Ma
t exist and failed to copy from blob store. > at > org.apache.flink.runtime.blob.BlobServer.getFileInternal(BlobServer.java:516) > at > org.apache.flink.runtime.blob.BlobServer.getFileInternal(BlobServer.java:444) > at org.apache.flink.runtime.blob.BlobServer.getFile(BlobServer.java:36

Re: What is Could not retrieve file from transient blob store?

2021-11-04 Thread Guowei Ma
leInternal(BlobServer > .java:516) > at org.apache.flink.runtime.blob.BlobServer.getFileInternal(BlobServer > .java:444) > at org.apache.flink.runtime.blob.BlobServer.getFile(BlobServer.java: > 369) > at org.apache.flink.runtime.rest.handler.taskmanager. > AbstractTaskMan

Re: Data Stream countWindow followed by keyBy does not preserve time order

2021-11-04 Thread Guowei Ma
ch mode, but the problem is that I > wont know when a batch job finishes if I don't run it in batch mode since a > streaming process will never end. > > Thanks. > > On Wed, Nov 3, 2021 at 4:38 PM Guowei Ma wrote: > >> Hi, Yan >> I do not think it is a bug. Maybe we co

Re: Data Stream countWindow followed by keyBy does not preserve time order

2021-11-03 Thread Guowei Ma
n Wed, Nov 3, 2021 at 1:58 PM Guowei Ma wrote: > >> Hi >> >> I did not run your program directly, but I see that you are now using the >> Batch execution mode. I suspect it is related to this, because in the Batch >> execution mode FLINK will "sort" t

Re: Question on BoundedOutOfOrderness

2021-11-03 Thread Guowei Ma
Hi Oliver I think Alexey is right that you could not assume that the record would be output in the event time order. And there is a small addition.I see your output and there are actually multiple concurrencies (probably 11 subtasks). You also can't expect these concurrencies to be ordered

Re: Why do the count windows in Flink Table APIs require processing time for sorting whereas in Flink Datastream APIs they do not

2021-11-03 Thread Guowei Ma
Hi Long >From the API point of view, this processing time can be omitted. This is mainly for unification: event-time scenarios, and alignment with other window APIs. Thanks Jark Wu for telling me this offline. Best, Guowei On Wed, Nov 3, 2021 at 11:55 AM Long Nguyễn wrote: > I have read

Re: Is there a way to update checkpoint configuration for a job "in-place"?

2021-11-03 Thread Guowei Ma
Hi Kevin If you want to change this configuration(execution.checkpointing.timeout) without restarting the job, as far as I know, there may not be such a method. But could you consider increasing this value by default? Best, Guowei On Wed, Nov 3, 2021 at 5:15 AM Kevin Lam wrote: > Hi all, > >

Re: New blog post published - Sort-Based Blocking Shuffle Implementation in Flink

2021-11-03 Thread Guowei Ma
Thank Daisy& Kevin much for your introduction to the improvement of TM blocking shuffle, credit base+io scheduling is indeed a very interesting thing. At the same time, I look forward to this as a default setting for tm blocking shuffle. Best, Guowei On Wed, Nov 3, 2021 at 2:46 PM Gen Luo

Re: What is Could not retrieve file from transient blob store?

2021-11-03 Thread Guowei Ma
Hi, Smith It seems that the log file(blob_t-274d3c2d5acd78ced877d898b1877b10b62a64df- 590b54325d599a6782a77413691e0a7b) is deleted for some reason. But AFAIK there are no other guys reporting this exception.(Maybe other guys know what would happen). 1. I think if you could refresh the page and

Re: Data Stream countWindow followed by keyBy does not preserve time order

2021-11-02 Thread Guowei Ma
Hi I did not run your program directly, but I see that you are now using the Batch execution mode. I suspect it is related to this, because in the Batch execution mode FLINK will "sort" the Key (this might be an unstable sort). So would you like to experiment with the results of running with

Re: Flink sink data to DB and then commit data to Kafka

2021-11-02 Thread Guowei Ma
Hi, Qihua AFAIK there is no way to do it. Maybe you need to implement a "new" sink to archive this target. Best, Guowei On Wed, Nov 3, 2021 at 12:40 PM Qihua Yang wrote: > Hi, > > Our flink application has two sinks(DB and kafka topic). We want to push > same data to both sinks. Is it

Re: Write Streaming data to S3 in Parquet files

2021-09-27 Thread Guowei Ma
e given? > Also I see that the FileSink takes GenericRecord, so how can the > DataStream be converted to a GenericRecord? > > Please bear with me if my questions don't make any sense. > > On Sun, Sep 26, 2021 at 9:12 AM Guowei Ma wrote: > >> Hi, Harshvardhan >> >&

Re: Write Streaming data to S3 in Parquet files

2021-09-25 Thread Guowei Ma
Hi, Harshvardhan I think CaiZhi is right. I only have a small addition. Because I see that you want to convert Table to DataStream, you can look at FileSink (ParquetWriterFactory)[1]. [1]

Re: Job Manager went down on cancelling job with savepoint

2021-09-25 Thread Guowei Ma
Hi, Puneet Could you share whether you are using Flink's session mode or application mode? >From the log, you are using `StandaloneDispatcher`, but you will use it in both session and application mode. If you use application mode, this might be in line with expectations. Best, Guowei On Fri,

Re: stream processing savepoints and watermarks question

2021-09-24 Thread Guowei Ma
mer plus an interval time. > If a MAX_WATERMARK comes, the timer is triggered, then registers another > timer and forever. > I'm not sure whether Macro meets a similar problem. > > Best, > JING ZHANG > > > > Guowei Ma 于2021年9月24日周五 下午4:01写道: > >> Hi Macro >>

Re: stream processing savepoints and watermarks question

2021-09-24 Thread Guowei Ma
Hi Macro Indeed, as mentioned by JING, if you want to drain when triggering savepoint, you will encounter this MAX_WATERMARK. But I have a problem. In theory, even with MAX_WATERMARK, there will not be an infinite number of timers. And these timers should be generated by the application code. You

Re: Exact S3 Permissions to allow a flink job to use s3 for checkpointing

2021-09-24 Thread Guowei Ma
Hi, Thomas I am not an expert of s3 but I think Flinkneed write/read/delete(maybe list) permission of the path(bucket). BTW, What error did you encounter? Best, Guowei On Fri, Sep 24, 2021 at 5:00 AM Thomas Wang wrote: > Hi, > > I'm trying to figure out what exact s3 permissions does a flink

Re: byte array as keys in Flink

2021-09-24 Thread Guowei Ma
Hi Hill As far as I know you could not use byte[] as a keyby. You could find more information from [1]. [1] https://nightlies.apache.org/flink/flink-docs-release-1.13/docs/dev/datastream/operators/overview/#keyby Best, Guowei On Fri, Sep 24, 2021 at 3:15 PM Caizhi Weng wrote: > Hi! > > It

Re: Flink Native Kubernetes - Configuration kubernetes.flink.log.dir not working

2021-09-14 Thread Guowei Ma
y I can pull the logs? > > Thanks, > Hemant > > On Tue, Sep 14, 2021 at 12:22 PM Guowei Ma wrote: > >> Hi, >> >> Could you share some logs when the job fails? >> >> Best, >> Guowei >> >> >> On Mon, Sep 13, 2021 at 10:59 PM bat man wr

Re: JVM Metaspace capacity planning

2021-09-14 Thread Guowei Ma
Hi, Puneet In general every job has its own classloader. You could find more detailed information from doc [1]. You could put some common jar into the "/lib" to avoid this [2]. [1] https://nightlies.apache.org/flink/flink-docs-release-1.13/docs/ops/debugging/debugging_classloading/ [2]

Re: Flink Native Kubernetes - Configuration kubernetes.flink.log.dir not working

2021-09-14 Thread Guowei Ma
Hi, Could you share some logs when the job fails? Best, Guowei On Mon, Sep 13, 2021 at 10:59 PM bat man wrote: > Hi, > > I am running a POC to evaluate Flink on Native Kubernetes. I tried > changing the default log location by using the configuration - > kubernetes.flink.log.dir > However,

Re: Flink Task/Operator metrics renaming

2021-09-13 Thread Guowei Ma
Hi, Ashutosh As far as I know, there is no way to rename the system metrics name. But would you like to share why you need to rename the metrics ? Best, Guowei On Mon, Sep 13, 2021 at 2:29 PM Ashutosh Uttam wrote: > Hi team, > > We are using PrometheusReporter to expose Flink metrics to

Re: TaskManagers OOM'ing for Flink App with very large state only when restoring from checkpoint

2021-09-13 Thread Guowei Ma
Hi, Kevin 1. Could you give me some specific information, such as what version of Flink is you using, and is it using DataStream or SQL? 2. As far as I know, RocksDB will put state on disk, so it will not consume memory all the time and cause OOM in theory. So you can see if there are any

Re: Triggers for windowed aggregations in Table API

2021-09-06 Thread Guowei Ma
gt; > Thanks, > > On Thu, Sep 2, 2021 at 9:24 PM Guowei Ma wrote: > >> Hi, John >> >> I agree with Caizhi that you might need to customize a window trigger. >> But there is a small addition, you need to convert Table to DataStream >> first. >> Then

Re: Triggers for windowed aggregations in Table API

2021-09-02 Thread Guowei Ma
Hi, John I agree with Caizhi that you might need to customize a window trigger. But there is a small addition, you need to convert Table to DataStream first. Then you can customize the trigger of the window. Because as far as I know, Table API does not support custom windows yet. For details on

Re: Flink on Kubernetes

2021-09-02 Thread Guowei Ma
Hi, Julian I notice that your configuration includes "restart-strategy.fixed-delay.attempts: 10". It means that the job would fail after 10 times failure. So maybe it leads to the job not restarting again and you could increase this value. But I am not sure if this is the root cause. So if this

Re: Verifying max-parallelism value

2021-09-02 Thread Guowei Ma
Hi, Niklas As far as I know, the maximum parallelism is not currently displayed on the web ui. Maximum parallelism is the concept of operator granularity, so I understand that it is a little difficult to show it. However, each job can have its own default value, if not, there is a calculation

Re: Odd Serialization exception

2021-08-12 Thread Guowei Ma
nTotalEvents > super.invoke(value, context) > sessionsWritten.inc() > } > > Though I still get Caused by: org.apache.flink.util.SerializedThrowable: > null > So, my assumption is that something wrong with "override def open()" method > > Thanks!

Re: Odd Serialization exception

2021-08-11 Thread Guowei Ma
Hi, Daniel Could you tell me the version of Flink you use? I want to look at the corresponding code. Best, Guowei On Wed, Aug 11, 2021 at 11:23 PM Daniel Vol wrote: > Hi Matthias, > > First, thanks for a fast reply. > I am new to Flink, so probably I miss a lot in terms of flow and objects >

Re: Flink 1.4.1 randomically responds HTTP 500 when sending job to Job Manager

2021-06-25 Thread Guowei Ma
Hi Burcu Could you show more logs? I could try to help find out what is happening. But to be honest the 1.4 is too old a version that the community does not support. You’d better upgrade to a newer version. Best, Guowei On Fri, Jun 25, 2021 at 2:48 PM Burcu Gül POLAT EĞRİ wrote: > Dear All, >

Re: Metric for JVM Overhaed

2021-06-25 Thread Guowei Ma
Hi Pranjul There are already some system metrics that track the jvm status(CPU/Memory/Threads/GC). You could find them in the [1] [1] https://ci.apache.org/projects/flink/flink-docs-release-1.13/docs/ops/metrics/#system-metrics Best, Guowei On Fri, Jun 25, 2021 at 2:33 PM Pranjul Ahuja wrote:

Re: Flink State Processor API Example - Java

2021-06-24 Thread Guowei Ma
Hi Sandeep What I understand is that you want to manipulate the state. So I think you could use the old schema to read the state first, and then write it to a new schema, instead of using a new schema to read an old schema format data. In addition, I would like to ask, if you want to do "State

Re: Flink checkpoint periodically fail

2021-06-24 Thread Guowei Ma
Hi Qihua It seems that the job fail because of checkpoint timeout(10min) from the second picture. I found that the checkpoint fail is because one of your own customs source could not acknowledge the cp. So I think you could add some log in your source to figure out what is happening at the moment.

Re: Checkpoint loading failure

2021-06-16 Thread Guowei Ma
Hi Padarn Will there be these errors if the jobgraph is not modified? In addition, is this error stack all? Is it possible that other errors caused the stream to be closed? Best, Guowei On Tue, Jun 15, 2021 at 9:54 PM Padarn Wilson wrote: > Hi all, > > We have a job that has a medium size

Re: Got multiple issues when running the tutorial project "table-walkthrough" on IDEA

2021-06-16 Thread Guowei Ma
Hi, Lingfeng These job errors you posted happened when the job(`SpendReport`) was running on the IDE? According to my understanding, this document[1] & repository[2] mean that the example is to be run in docker, not in IDE. [1]

Re: Discard checkpoint files through a single recursive call

2021-06-15 Thread Guowei Ma
hi, Jiang I am afraid of misunderstanding what you mean, so can you elaborate on how you want to change it? For example, which interface or class do you want to add a method to? Although I am not a state expert, as far as I know, due to incremental checkpoints, when CompleteCheckpoint is

Re: DataStream API in Batch Execution mode

2021-06-07 Thread Guowei Ma
Hi, Macro I think you could try the `FileSource` and you could find an example from [1]. The `FileSource` would scan the file under the given directory recursively. Would you mind opening an issue for lacking the document? [1]

Re: How do you debug a DataStream flat join on common window?

2021-05-24 Thread Guowei Ma
Hi, Would you like to share your code? It is very helpful to verify the problem. I think you could use the `JoinedStream.with().uid(xxx)` to set the name/UID . Best, Guowei On Mon, May 24, 2021 at 2:36 PM Marco Villalobos wrote: > Hi, > > Stream one has one element. > Stream two has 2

Re: Task not serializable when logging in a trait method

2021-05-24 Thread Guowei Ma
Hi, Yik San You need to change the following line: protected final val LOG = LoggerFactory.getLogger(getClass) protected *static* final val LOG = LoggerFactory.getLogger(getClass) Best, Guowei On Mon, May 24, 2021 at 2:41 PM Yik San Chan wrote: > Hi community, > > I have a job that

Re: count the amount of data successfully processed by flink

2021-05-24 Thread Guowei Ma
Hi I think you are right that the metrics are reset after the job restart. It is because the metrics are only stored in the memory. I think you could store the metrics to the Flink's state[1], which could be restored after the job restarted. [1]

Re: Root Exception can not be shown on Web UI in Flink 1.13.0

2021-05-13 Thread Guowei Ma
Hi, Gary I think it might be a bug. So would you like to open a jira for this. And could you share the exception ,which the TaskManagerLocation is null? It might be very helpful to verify the cause. Best, Guowei On Thu, May 13, 2021 at 10:36 AM Yangze Guo wrote: > Hi, it seems to be related

Re: How does JobManager terminate dangling task manager

2021-05-13 Thread Guowei Ma
Hi, In fact, not only JobManager(ResoruceManager) will kill TimeOut's TaskManager, but if TaskManager finds that it cannot connect to JobManager(ResourceManager), it will also exit by itself. You can look at the time period during which the HB timeout occurred and what happened in the log. Under

Re: Flink sql task failure recovery does not work.

2021-05-13 Thread Guowei Ma
Hi I think you could configure some restart strategy[1] likes restart-strategy: fixed-delay [1] https://ci.apache.org/projects/flink/flink-docs-release-1.13/docs/dev/execution/task_failure_recovery/#fixed-delay-restart-strategy Best, Guowei On Thu, May 13, 2021 at 12:02 PM 1095193...@qq.com

Re: Need Clarity about Checkpoint for Flink-1.12.2

2021-05-13 Thread Guowei Ma
Hi Sudhansu, I think you do not need to set the config in flink-conf. Best, Guowei On Thu, May 13, 2021 at 1:06 PM sudhansu jena wrote: > Hi Team, > > We have recently enabled Check Pointing in our flink job using > FSStateBackend pointing to S3 bucket. > > Below is the sample code for

Re: docker based taskmanager can't connect to job/resource manager

2021-05-12 Thread Guowei Ma
for your reply! This information was still missing. The presenter > mentioned the documentation but I hadn't found it. So your link to the > specific place is valuable too. > > Günter > On 13.05.21 06:09, Guowei Ma wrote: > > Hi, > I do not try it. But from the documentation[

Re: docker based taskmanager can't connect to job/resource manager

2021-05-12 Thread Guowei Ma
Hi, I do not try it. But from the documentation[1] it seems that you might need add the "jobmanager.rpc.address: jobmanager" to the FLINK_PROPERTIES before creating a network. [1] https://ci.apache.org/projects/flink/flink-docs-master/docs/deployment/resource-providers/standalone/docker/ Best,

Re: How to config the flink to load libs in myself path

2021-04-19 Thread Guowei Ma
Hi, chenxuying There is currently no official support for this. What I am curious about is why you have this requirement. In theory, you can always build your own image. Best, Guowei On Mon, Apr 19, 2021 at 9:58 PM chenxuying wrote: > Hi all, I deployed the flink in K8S by session cluster [1]

Re: Max-parellelism limitation

2021-04-19 Thread Guowei Ma
Hi, Olivier Yes. The introduction of this concept is to solve the problem of rescaling the keystate. Best, Guowei On Mon, Apr 19, 2021 at 8:56 PM Olivier Nouguier wrote: > Hi, > May I have the confirmation that the max-parallelism limitation only > occurs when keyed states are used ? > > >

Re: Accessing columns from input stream table during Window operations

2021-04-19 Thread Guowei Ma
;> .execute_insert('MySink') \ >> .wait() >> >> But running into following exception: >> >> py4j.protocol.Py4JError: An error occurred while calling >> z:org.apache.flink.table.api.Over.partitionBy. Trace: >> org.apache.flink.api.python.shaded.

Re: Batch Task Synchronization

2021-04-19 Thread Guowei Ma
Hi, Mary Flink has an alignment mechanism for synchronization. All upstream taks (for example reduce1) will send a message after the end of a round to inform all downstream that he has processed all the data. When the downstream (reduce2) collected all the messages from all his upstream

Re: Accessing columns from input stream table during Window operations

2021-04-19 Thread Guowei Ma
pass through > from input to sink. What's the best way to achieve this? I was thinking > that making it part of the select() clause would do it, but as you said > there needs to be some aggregation performed on it. > > Thanks, > Sumeet > > > On Mon, Apr 19, 2021 at 12

Re: Accessing columns from input stream table during Window operations

2021-04-19 Thread Guowei Ma
Hi, Sumeet For "input.b" I think you should aggregate the non-group-key column[1]. But I am not sure why the "input.c.avg.alias('avg_value')" has resolved errors. Would you mind giving more detailed error information? [1]

Re: [DISCUSS] Feature freeze date for 1.13

2021-04-01 Thread Guowei Ma
it's a >>>> useful improvement to sql client and won't affect >>>> other components too much. We were plan to merge it yesterday but met >>>> some tricky multi-process issue which >>>> has a very high possibility hanging the tests. It took us a while

Re: Flink Taskmanager failure recovery and large state

2021-04-01 Thread Guowei Ma
cksDBStateBackend{checkpointStreamBackend=File State > Backend (checkpoints: 'gs:///flink-checkpoints', savepoints: > 'gs:///flink-savepoints', asynchronous: TRUE, fileStateThreshold: > 1048576), localRocksDbDirectories=[/rocksdb], > enableIncrementalCheckpointing=TRUE, numberOfTransferT

Re: s3 FileSystem Error "s3 file system implementation does not support recoverable writers"

2021-04-01 Thread Guowei Ma
nt.java:5062) > ~[?:?] > at > com.amazonaws.services.s3.AmazonS3Client.invoke(AmazonS3Client.java:5008) > ~?:?] > at > com.amazonaws.services.s3.AmazonS3Client.initiateMultipartUpload(AmazonS3Client.java:3581) > ~[?:?] > at > org.apache.hadoop.fs.s3a.S3A

Re: Checkpoint timeouts at times of high load

2021-04-01 Thread Guowei Ma
Hi, I think there are many reasons that could lead to the checkpoint timeout. Would you like to share some detailed information of checkpoint? For example, the detailed checkpoint information from the web.[1] And which Flink version do you use? [1]

Re: Flink Taskmanager failure recovery and large state

2021-04-01 Thread Guowei Ma
Hi, Yaroslav AFAIK there is no official GCS FileSystem support in FLINK. Does the GCS is implemented by yourself? Would you like to share the whole log of jm? BTW: From the following log I think the implementation has already some retry mechanism. >>> Interrupted while sleeping before retry.

Re: ARM support

2021-04-01 Thread Guowei Ma
Hi, Rex I think that Flink does not have an official release that supports the arm architecture. There are some efforts and discussion [1][2][3] about supporting the architecture. I think you could find some builds at openlabtesting. [4] But AFAIK there is no clear timeline about that.(correct me

Re: PyFlink: Extract nested fields from JSON array

2021-03-31 Thread Guowei Ma
Hi, Sumeet I am not an expert about PyFlink. But I think @Dian Fu might give some insight about this problem. Best, Guowei On Thu, Apr 1, 2021 at 12:12 AM Sumeet Malhotra wrote: > Cross posting from StackOverlow here: > > >

Re: Measuring the Size of State, Savepoint Size vs. Restore time

2021-03-31 Thread Guowei Ma
Hi, Kevin If you use the RocksDB and want to know the data on the disk I think that is the right metric. But the SST files might include some expired data. Some data in memory is not included in the SST files yet. In general I think it could reflect the state size of your application. I think

Re: s3 FileSystem Error "s3 file system implementation does not support recoverable writers"

2021-03-31 Thread Guowei Ma
Hi, Robert I think you could try to change the "s3://argo-artifacts/" to " s3a://argo-artifacts/". It is because that currently `StreamingFileSink` only supports Hadoop based s3 but not Presto based s3. [1] [1]

Re: [DISCUSS] Feature freeze date for 1.13

2021-03-31 Thread Guowei Ma
Hi, community: Friendly reminder that today (3.31) is the last day of feature development. Under normal circumstances, you will not be able to submit new features from tomorrow (4.1). Tomorrow we will create 1.13.0-rc0 for testing, welcome to help test together. After the test is relatively

Re: Native kubernetes execution and History server

2021-03-25 Thread Guowei Ma
NK_HOME}/plugins/s3-fs-presto > COPY flink-s3-fs-presto-1.12.2.jar $FLINK_HOME/plugins/s3-fs-presto/ > > Thanks! > > On Thu, Mar 25, 2021 at 9:24 AM Guowei Ma wrote: > >> Hi, >> After some discussion with Wang Yang offline, it seems that there might >> be a job

Re: flink sql jmh failure

2021-03-25 Thread Guowei Ma
Hi, I am not an expert of JMH but it seems that it is not an error. From the log it looks like that the job is not finished. The data source continues to read data when JMH finishes. Thread[Legacy Source Thread - Source: TableSourceScan(table=[[default_catalog, default_database,

Re: Native kubernetes execution and History server

2021-03-25 Thread Guowei Ma
Hi, After some discussion with Wang Yang offline, it seems that there might be a jobmanager failover. So would you like to share full jobmanager log? Best, Guowei On Wed, Mar 24, 2021 at 10:04 PM Lukáš Drbal wrote: > Hi, > > I would like to use native kubernetes execution [1] for one batch job

Re: Re: About Memory Spilling to Disk in Flink

2021-03-24 Thread Guowei Ma
Hi, Roc Thanks for your detailed explanation. I could not find any "stream" operator that uses `ExternalSorterBuilder` by "find usage" of the IDEA. Best, Guowei On Wed, Mar 24, 2021 at 3:27 PM Roc Marshal wrote: > Hi, Guowei Ma. > As far as I know, flink writes s

Re: About Memory Spilling to Disk in Flink

2021-03-24 Thread Guowei Ma
Hi, Roc Could you explain more about your question? Best, Guowei On Wed, Mar 24, 2021 at 2:47 PM Roc Marshal wrote: > Hi, > > Can someone tell me where flink uses memory spilling to write to disk? > Thank you. > > Best, Roc. > > > >

Re: Fault Tolerance with RocksDBStateBackend

2021-03-24 Thread Guowei Ma
Hi, You need some persistent storages(like hdfs) for the checkpoint. It is Flink's fault tolerance prerequisites.[1] [1] https://ci.apache.org/projects/flink/flink-docs-release-1.12/dev/stream/state/checkpointing.html#prerequisites Best, Guowei On Wed, Mar 24, 2021 at 1:21 PM Maminspapin

Re: Kubernetes Application Cluster Not Working

2021-03-23 Thread Guowei Ma
Hi, M Could you give the full stack? This might not be the root cause. Best, Guowei On Wed, Mar 24, 2021 at 2:46 AM Claude M wrote: > Hello, > > I'm trying to setup Flink in Kubernetes using the Application Mode as > described here: >

  1   2   >