Re: Timeout Callbacks issue -Flink

2020-05-25 Thread Dawid Wysakowicz
]. There even though a ValueState is used, we calculate counts per key. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.10/dev/stream/operators/process_function.html#example On 25/05/2020 11:17, Jaswin Shah wrote: > If I understand correctly, you are trying to t

Re: Timeout Callbacks issue -Flink

2020-05-25 Thread Dawid Wysakowicz
ill have at most single element in your map. Think of the MapState as a map of maps MapState = Map>. In your case a ValueState should be enough imo. Best, Dawid On 23/05/2020 14:39, Jaswin Shah wrote: > ++ > Here, I am registering the callback time for an even with processing > time and c

Re: How to read UUID out of a JDBC table source

2020-05-18 Thread Dawid Wysakowicz
edges, sorry about that. If you are implementing your own source make sure you return DataTypes.RAW(TypeInformation.of(UUID.class) in both the TableSchema and getProducedDataType. Best, Dawid On 14/05/2020 18:42, Bonino Dario wrote: > > Dear list, > > I need to use a Table Source to

Re: Register time attribute while converting a DataStream to Table

2020-05-13 Thread Dawid Wysakowicz
it in Flink 1.11. Best, Dawid [1] https://cwiki.apache.org/confluence/display/FLINK/FLIP-95%3A+New+TableSource+and+TableSink+interfaces On 13/05/2020 01:03, Jiahui Jiang wrote: > Hello Flink friends, I have a retract stream in the format of > 'DataStream' that I want to register i

Re: Flink BLOB server port exposed externally

2020-05-13 Thread Dawid Wysakowicz
Hi Omar, Theoretically I think it could be possible to change the address on which the BlobServer runs (even to localhost). There is no configuration option for it now and the BlobServer always binds to the wildcard. One important aspect to consider here is that the BlobServer must be accessible

Re: Flink consuming rate increases slowly

2020-05-13 Thread Dawid Wysakowicz
Hi Eyal, Could you explain your job a bit more? Did you increase the parallelism of your job? What does it do? Does it perform any time based operations? How do you measure the processing rate? Best, Dawid On 10/05/2020 21:18, Chen Qin wrote: > Hi Eyal, > > It’s unclear what warmup p

Re: Using logicalType in the Avro table format

2020-04-30 Thread Dawid Wysakowicz
really hope the effort of FLIP-95 will significantly reduce the number of problems. It's definitely worth reporting a bug. BTW could you share how you create the Kafka Table sink to have the full picture? Best, Dawid On 29/04/2020 15:42, Gyula Fóra wrote: > Hi All! > > We are tryin

Re: [DISCUSS] Hierarchies in ConfigOption

2020-04-29 Thread Dawid Wysakowicz
'     option: 'value' Best, Dawid On 29/04/2020 17:13, Flavio Pompermaier wrote: > Personally I don't have any preference here.  Compliance wih standard > YAML parser is probably more important > > On Wed, Apr 29, 2020 at 5:10 PM Jark Wu <mailto:imj...@gmail.com>> wrote: > >

Re: [DISCUSS] Hierarchies in ConfigOption

2020-04-29 Thread Dawid Wysakowicz
'     option: 'value' Best, Dawid On 29/04/2020 17:13, Flavio Pompermaier wrote: > Personally I don't have any preference here.  Compliance wih standard > YAML parser is probably more important > > On Wed, Apr 29, 2020 at 5:10 PM Jark Wu <mailto:imj...@gmail.com>> wrote: > >

Re: Cannot map nested Tuple fields to table columns

2020-04-27 Thread Dawid Wysakowicz
he bug you could reorder and rename at the same time:    tableEnv.fromDataStream(input, “f1 as name, f2 as age, f0 as height") // it reorders the fields of the pojo to the order f1,f2,f0 and give them aliases With a fix it should be possible yes. Best, Dawid On 27/04/2020 17:24, Gyula Fóra

Re: Cannot map nested Tuple fields to table columns

2020-04-27 Thread Dawid Wysakowicz
nstanceof UnresolvedReferenceExpression) {** **                return false;** **            }*             if (f instanceof UnresolvedReferenceExpression) {                 return !inputNames.contains(((UnresolvedReferenceExpression) f).getName());             }             return true;         });     } Be

Re: Fault tolerance in Flink file Sink

2020-04-24 Thread Dawid Wysakowicz
Forgot to cc Kostas On 23/04/2020 12:11, Eyal Pe'er wrote: > > Hi all, > I am using Flink streaming with Kafka consumer connector > (FlinkKafkaConsumer) and file Sink (StreamingFileSink) in a cluster > mode with exactly once policy. > > The file sink writes the files to the local disk. > > I’ve

Re: Fault tolerance in Flink file Sink

2020-04-24 Thread Dawid Wysakowicz
out the StreamingFileSink than I do., so he can maybe correct me somewhere.  Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.10/dev/connectors/streamfile_sink.html [2] https://ci.apache.org/projects/flink/flink-docs-release-1.10/dev/connectors/kafka.html [3]https://ci.a

Re: When i use the Tumbling Windows, find lost some record

2020-03-26 Thread Dawid Wysakowicz
Hi, Can you share more details what do you mean that you loose some records? Can you share what data are you ingesting what are the expected results and what are the actual results you are getting. Without that it's impossible to help you. So far your code looks rather correct. Best, Dawid

Re: How to calculate one alarm strategy for each device or one alarm strategy for each type of IOT device

2020-03-25 Thread Dawid Wysakowicz
. If you need access to timers you can also have a look at the KeyedProcessFunction[1] instead of FlatMap function. E.g. if you want to find only 10 consecutive events with temperature higher than 10 that happened within one hour. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs

Re: Kerberos authentication for SQL CLI

2020-03-24 Thread Dawid Wysakowicz
to query the schema even before submitting the job. Best, Dawid On 24/03/2020 13:50, Gyula Fóra wrote: > Thanks Dawid, > > I think you are right that most of the things should work like this > just fine. Maybe some catalogs will need this at some point but not > right now, > I wa

Re: Lack of KeyedBroadcastStateBootstrapFunction

2020-03-24 Thread Dawid Wysakowicz
remember correctly worked on that API. I hope they might give you some more insights. Best, Dawid  On 23/03/2020 17:36, Mark Niehe wrote: > Hey all, > > I have another question about the State Processor API. I can't seem to > find a way to create a KeyedBroadcastStateBootstrapFunct

Re: How to calculate one alarm strategy for each device or one alarm strategy for each type of IOT device

2020-03-24 Thread Dawid Wysakowicz
Hi, Could you elaborate a bit more what do you want to achieve. What have you tried so far? Could you share some code with us? What problems are you facing? From the vague description you provided you should be able to design it with e.g. KeyedProcessFunction[1] Best, Dawid [1] https

Re: Importance of calling mapState.clear() when no entries in mapState

2020-03-24 Thread Dawid Wysakowicz
I think there should be no reason to do that. Best, Dawid On 24/03/2020 09:29, Ilya Karpov wrote: > Hi, > > given: > - flink 1.6.1 > - stateful function with MapState mapState = //init logic; > > Is there any reason I should call mapState.clear()

Re: Kerberos authentication for SQL CLI

2020-03-24 Thread Dawid Wysakowicz
the Kerberos authentication for? Best, Dawid On 24/03/2020 11:11, Gyula Fóra wrote: > Hi! > > Does the SQL CLI support Kerberos Authentication? > > I am struggling to find any use of the SecurityContext in the SQL CLI > logic but maybe I am looking in the wrong place. >

Re: Flink EventTime Processing Watermark is always coming as 9223372036854725808

2020-03-02 Thread Dawid Wysakowicz
they work here: https://ci.apache.org/projects/flink/flink-docs-master/dev/event_time.html#watermarks-in-parallel-streams Hope that helps Best, Dawid On 02/03/2020 16:26, aj wrote: > > I am trying to use process function to some processing on a set of > events. I am using e

Re: Schema registry deserialization: Kryo NPE error

2020-03-02 Thread Dawid Wysakowicz
) // must be provided again, as the map transformation is a black box, the transformation might produce a completely different record Hope that helps a bit. Best, Dawid On 02/03/2020 09:04, Arvid Heise wrote: > Hi Nitish, > > Kryo is the fallback serializer of Flink when everything e

Re: TIME/TIMESTAMP parse in Flink TABLE/SQL API

2020-02-26 Thread Dawid Wysakowicz
d by default). As I understand the RFC, making the time zone mandatory is actually a big part of the standard as it makes time types unambiguous. What do you think? Ps. I cross posted this on the dev ML. Best, Dawid On 26/02/2020 03:45, Jark Wu wrote: > Yes, I'm also in favor of loosen the datet

Re: StreamingFileSink Not Flushing All Data

2020-02-24 Thread Dawid Wysakowicz
cc Kostas who should be able to correct me if I am wrong. Best, Dawid On 22/02/2020 01:59, Austin Cawley-Edwards wrote: > Hi there, > > Using Flink 1.9.1, trying to write .tgz files with the > StreamingFileSink#BulkWriter. It seems like flushing the output stream > doesn't flu

Re: [DISCUSS] Drop Savepoint Compatibility with Flink 1.2

2020-02-24 Thread Dawid Wysakowicz
+1 for dropping Best, Dawid On 24/02/2020 08:22, Yu Li wrote: > +1 for dropping savepoint compatibility with Flink 1.2. > > Best Regards, > Yu > > > On Sat, 22 Feb 2020 at 22:05, Ufuk Celebi <mailto:u...@apache.org>> wrote: > > Hey Stephan, > &g

[DISCUSS] Drop connectors for Elasticsearch 2.x and 5.x

2020-02-10 Thread Dawid Wysakowicz
the 5.x line to a working es client module. What do you think? Should we drop both versions? Drop only the 2.x connector? Or keep them both? Best, Dawid signature.asc Description: OpenPGP digital signature

Re: Performance issue with RegistryAvroSerializationSchema

2020-02-06 Thread Dawid Wysakowicz
to track it https://issues.apache.org/jira/browse/FLINK-15941 Would you maybe like to check it and prepare a fix for it ;) ? Best, Dawid On 06/02/2020 16:11, Robert Metzger wrote: > Hi, > thanks a lot for your message. It's certainly not intentional to do a > HTTP request for eve

Re: Is there a way to clean up the state based on custom/business logic?

2020-01-14 Thread Dawid Wysakowicz
] will be a better fit for you. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.9/dev/stream/operators/process_function.html On 14/01/2020 11:33, kant kodali wrote: > Hi All, > > I read through the doc below and I am wondering if I can clean up the > state based on custom

Re: Using async io in cep

2020-01-08 Thread Dawid Wysakowicz
If I am not mistaken, my previous answer is still valid. There is no way to have true asynchronicity within CEP conditions. Why do you want to use async io there? Did you hit performance issues? If so, you could try increasing the parallelism. Best, Dawid On 07/01/2020 02:47, 郑 洁锋 wrote

Re: Table API: Joining on Tables of Complex Types

2020-01-08 Thread Dawid Wysakowicz
GenericRecordAvroTypeInfo(/*schema string*/) than the TableEnvironment should pick it up as a structured type and flatten it automatically when registering the Table. Bear in mind the returns method is part of SingleInputUdfOperator so you can apply it right after some transformation e.g. map/flatMap etc. Best, Dawid

Re: Flink logging issue with logback

2020-01-07 Thread Dawid Wysakowicz
A quick update. The suppression of stdout/stderr actually might soon be dropped, see: https://issues.apache.org/jira/browse/FLINK-15504 Best, Dawid On 07/01/2020 07:17, Yang Wang wrote: > Hi Bajaj, > > I have tested just as you say, and find that the logs in the user > class could

Re: Flink logging issue with logback

2020-01-07 Thread Dawid Wysakowicz
clarifies the difference. Best, Dawid On 07/01/2020 07:17, Yang Wang wrote: > Hi Bajaj, > > I have tested just as you say, and find that the logs in the user > class could not show up when > using ConsoleAppender. If using FileAppender instead, everything goes > well.  > > It is so wei

Re: Table API: Joining on Tables of Complex Types

2020-01-06 Thread Dawid Wysakowicz
zationSchema class is implemented which internally converts an avro record to a structured Row. Hope this helps. Best, Dawid On 03/01/2020 23:16, Hailu, Andreas wrote: > > Hi folks, > >   > > I’m trying to join two Tables which are composed of complex types, > Avro’s Generi

Re: Flink group with time-windowed join

2020-01-06 Thread Dawid Wysakowicz
AND     a.producer_timestamp BETWEEN b.producer_timestamp - INTERVAL '3' MINUTE AND b.producer_timestamp group by     a.account,     TUMBLE(a.producer_timestamp, INTERVAL '3' MINUTE) Best, Dawid On 04/01/2020 04:06, Kurt Young wrote: > Looks like a bug to me, could you fire an is

Re: Flink logging issue with logback

2020-01-06 Thread Dawid Wysakowicz
. How did you check the logs? If you checked through the Web UI could you try to check the file directly? Ad. 2 Yes this is expected. Operators are executed on taskmanager and that's why they log there. Ad. 3 See Ad. 1 Best, Dawid On 06/01/2020 07:07, vino yang wrote: > Hi Bajaj, > >

Re: Using async io in cep

2020-01-06 Thread Dawid Wysakowicz
require a careful key processing. If I am not mistaken Async IO also does not support a stateful processing on a keyed stream. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.9/dev/stream/operators/asyncio.html On 06/01/2020 09:59, 郑 洁锋 wrote: > Hi, >         Is there

Re: How to convert retract stream to dynamic table?

2019-12-19 Thread Dawid Wysakowicz
[1] to implement that before, but we must clarify all aspects of such operation first. Best, Dawid [1] https://github.com/apache/flink/pull/6787 On 19/12/2019 04:05, Kurt Young wrote: > Hi James, > > If I understand correctly, you can use `TableEnvironment#sqlQuery` to > achieve >

Re: Kafka table descriptor missing startFromTimestamp()

2019-12-19 Thread Dawid Wysakowicz
Hi, The only reason why it was not exposed at the beginning is that not all versions of the consumers support starting from a specific timestamp. I think we could expose such setting now. Would you like to create an issue for it? Best, Dawid On 19/12/2019 06:56, Steve Whelan wrote: > Examin

Re: Open Method is not being called in case of AggregateFunction UDFs

2019-12-11 Thread Dawid Wysakowicz
Hi Arujit, Could you also share the query where you use this UDF? It would also help if you said which version of Flink you are using and which planner. Best, Dawid On 11/12/2019 10:21, Arujit Pradhan wrote: > Hi all, > > So we are creating some User Defined Function

Re: Some doubts about window start time and end time

2019-11-29 Thread Dawid Wysakowicz
. The offset actually means an offset within a window. You can shift the window a bit, but you cannot shift the whole timeline. That's why the offset must be smaller than the window size. Best, Dawid On 27/11/2019 11:44, Jun Zhang wrote: > > Hi,Caizhi : > 1.if I add offset ,

Re: How to recover state from savepoint on embedded mode?

2019-11-29 Thread Dawid Wysakowicz
/confluence/display/FLINK/FLIP-74%3A+Flink+JobClient+API). Best, Dawid On 28/11/2019 19:56, Arvid Heise wrote: > Just to add up, if you use LocalStreamEnvironment, you can pass a > configuration and you can set"execution.savepoint.path" to point to > your savepoint. > > B

Re: Propagating event time field from nested query

2019-11-14 Thread Dawid Wysakowicz
somehow. Best, Dawid On 11/11/2019 22:43, Piyush Narang wrote: > > Hi folks, > >   > > We have a Flink streaming Table / SQL job that we were looking to > migrate from an older Flink release (1.6.x) to 1.9. As part of doing > so, we have been seeing a few errors which I

Re: [FlinkSQL] is there a way to read/write local json data in Flink SQL like that of kafka?

2019-10-29 Thread Dawid Wysakowicz
in = input.map(jsonSchema::deserialize)             .returns(producedType);         tEnv.registerDataStream("t", in); Table table = tEnv.sqlQuery("SELECT * FROM t"); Best, Dawid On 29/10/2019 10:59, Anyang Hu wrote: > Hi guys, > > In flink1.9, we can set `

Re: add() method of AggregateFunction not called even though new watermark is emitted

2019-10-14 Thread Dawid Wysakowicz
Hi Vijay, Could you check if the Watermark for the aggregate operator advances? You should be able to check that in the Flink WebUI. Could it be that the Watermark does not advance for all of the upstream operators? The watermark for a particular operator is a minimum of watermarks received from

Re: [PROPOSAL] Contribute Stateful Functions to Apache Flink

2019-10-11 Thread Dawid Wysakowicz
is to adopt an existing code base as is. It also proposes a new programs concept that could result in a shift of priorities for the community in a long run. Best, Dawid [1] http://apache-flink-mailing-list-archive.1008284.n3.nabble.com/DISCUSS-Create-a-Flink-ecosystem-website-td27519.html [2] https

Re: State & Fault Tolerance in Table API and SQL Implementations

2019-10-10 Thread Dawid Wysakowicz
this clarifies a bit how Table API interacts with Flink's state. Best, Dawid On 08/10/2019 12:09, Vaibhav Singh wrote: > Hi, > > We are looking into a production use case of using Flink, to process > multiple streams of data from Kafka topics. > > We plan to perform join

Re: CEP operator in SQL pattern match does not clear it's state

2019-10-01 Thread Dawid Wysakowicz
m I would not expect the memory consumption to go down, but it should saturate after some time and remain rather constant, but should not grow infinitely. I hope it helps. Best, Dawid On 01/10/2019 09:08, Muhammad Hakim wrote: > Hi All, > We've been experimenting with `MATCH_RECOGNIZE` claus

Re: Assigning UID to Flink SQL queries

2019-09-02 Thread Dawid Wysakowicz
. As of know it can also change between Flink version if we implement new optimizations, operators etc. Right now user also does not have access to the execution graph. This is though something that we definitely want to address at some point. Best, Dawid On 30/08/2019 12:51, Yuval Itzchakov

Re: [ANNOUNCE] Andrey Zagrebin becomes a Flink committer

2019-08-14 Thread Dawid Wysakowicz
Congratulations Andrey! Pleasure to have you in the community! Best, Dawid On 14/08/2019 16:06, Kostas Kloudas wrote: > Congratulations Andrey! > Well deserved! > > Kostas > > On Wed, Aug 14, 2019 at 4:04 PM Yun Tang wrote: >> Congratulations Andrey

Re: Flink cannot recognized catalog set by registerCatalog.

2019-08-12 Thread Dawid Wysakowicz
tEnv.getCatalog().createTable() or you can try using SQL DDL. Best, Dawid On 12/08/2019 09:37, Simon Su wrote: > Hi All >     I want to use a custom catalog by setting the name “ca1” and > create a database under this catalog. When I submit the  > SQL, and it raises the error like : >

Re: [ANNOUNCE] Hequn becomes a Flink committer

2019-08-07 Thread Dawid Wysakowicz
Congratulations Hequn! Glad to have you in the community! On 07/08/2019 10:28, jincheng sun wrote: > Hi everyone, > > I'm very happy to announce that Hequn accepted the offer of the Flink > PMC to become a committer of the Flink project. > > Hequn has been contributing to Flink for many years,

Re: Help with the correct Event Pattern

2019-07-26 Thread Dawid Wysakowicz
oes not have any effect. Best, Dawid On 25/07/2019 16:50, Federico D'Ambrosio wrote: > Hello everyone, > > I need a bit of help concerning a correct formulation for a Complex > Event Pattern, using CEP. > > I have a stream of events which once keyed for ids, they may look like &

Re: Can Flink infers the table columns type

2019-07-04 Thread Dawid Wysakowicz
to create DataSet/DataStream: StreamExecutionEnvironment.createInput/ExecutionEnvironment.createInput. You may expect more (table) connectors in the Flink versions 1.10+. They should have the automatic schema inference when possible. Best, Dawid On 02/07/2019 20:36, Soheil Pourbafrani wrote

Re: [ANNOUNCE] Apache Flink 1.8.1 released

2019-07-03 Thread Dawid Wysakowicz
Congrats to everyone involved and thank you Jincheng for being the release manager! On 03/07/2019 08:38, JingsongLee wrote: > Thanks jincheng for your great job. > > Best, JingsongLee > > -- > From:Congxian Qiu > Send

Re: CoFlatMapFunction vs BroadcastProcessFunction

2019-06-21 Thread Dawid Wysakowicz
rescale. I think you can say in this approach not only the stream is broadcasted, but also the state is broadcasted (on the broadcast side). As for the example you linked, I don't know enough about it to tell anything about what it does and why it does that way. Best, Dawid On 20/06/2019 12:39

Re: Apache Flink - How to pass configuration params in the flink-config.yaml file to local execution environment

2019-05-20 Thread Dawid Wysakowicz
Hi, You should be able to pass the Configuration via: org.apache.flink.streaming.api.environment.StreamExecutionEnvironment#createLocalEnvironment(int, org.apache.flink.configuration.Configuration) Regards, Dawid On 19/05/2019 20:49, M Singh wrote: > Hey Flink Folks: > > I was tryin

Re: Possilby very slow keyBy in program with no parallelism

2019-05-20 Thread Dawid Wysakowicz
for processing. Could you try decreasing this value? I can't help with explanation how the network buffers work, but I cc Piotr who should be more suited to provide meaningful information. Regards, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.8/dev/execution_configuration.html

Re: Possilby very slow keyBy in program with no parallelism

2019-05-20 Thread Dawid Wysakowicz
for processing. Could you try decreasing this value? I can't help with explanation how the network buffers work, but I cc Piotr who should be more suited to provide meaningful information. Regards, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.8/dev/execution_configuration.html

Re: Connecting to a service (Eg: Kafka, Cassandra) with different keytabs from the same cluster

2019-05-20 Thread Dawid Wysakowicz
of distributing security contexts[1], you can provide only a single credentials for a single Flink cluster. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-master/ops/security-kerberos.html#kerberos-authentication-setup-and-configuration On 20/05/2019 10:15, Kumar Bolar, Harshith

Re: FW: Constant backpressure on flink job

2019-05-20 Thread Dawid Wysakowicz
Hi, Have you checked the logs for exceptions? Could you share the logs with us? Have you tried switching to e.g. FSStateBackend or disabling the incremental checkpoints on 1.7.2 to see in what configuration the problem occurs? Best, Dawid On 20/05/2019 09:09, Georgi Stoyanov wrote: > > H

Re: Avro SerializationSchema for Confluent Registry

2019-05-03 Thread Dawid Wysakowicz
of the code there. Best, Dawid [1] https://github.com/apache/flink/pull/6259 On 03/05/2019 15:09, PoolakkalMukkath, Shakir wrote: > > Hi Till, > > Is there a Serialization schema for Kafka Producer when using > Confluent Registry ? I am trying to publish to a topic which u

Re: assignTimestampsAndWatermarks not work after KeyedStream.process

2019-04-26 Thread Dawid Wysakowicz
no Watermarks at all for this partition, therefore there is no progress beyond this point. I hope this clarifies it a bit. Best, Dawid On 25/04/2019 16:49, an0 wrote: > If my understanding is correct, then why `assignTimestampsAndWatermarks` > before `keyBy` works? The `timeWindowAll` st

Re: TM occasionally hang in deploying state in Flink 1.5

2019-04-25 Thread Dawid Wysakowicz
Hi, Feel free to open a JIRA for this issue. By the way have you investigated what is the root cause for it hanging? Best, Dawid On 25/04/2019 08:55, qi luo wrote: > Hello, > > This issue occurred again and we dumped the TM thread. It indeed hung > on socket read to download j

Re: Zeppelin

2019-04-25 Thread Dawid Wysakowicz
Hi Sergey, I am not very familiar with Zepellin. But I know Jeff (cc'ed) is working on integrating Flink with some notebooks. He might be able to help you. Best, Dawid On 25/04/2019 08:42, Smirnov Sergey Vladimirovich (39833) wrote: > > Hello, > >   > > Trying to link Zeppe

Re: QueryableState startup regression in 1.8.0 ( migration from 1.7.2 )

2019-04-25 Thread Dawid Wysakowicz
Hi Vishal, As Guowei mentioned you have to enable the Queryable state. The default setting was changed in 1.8.0. There is an open JIRA[1] for changing the documentation accordingly. Best, Dawid [1] https://issues.apache.org/jira/browse/FLINK-12274 On 25/04/2019 03:27, Guowei Ma wrote: >

Re: Job Startup Arguments

2019-04-25 Thread Dawid Wysakowicz
Hi Steve, As far as I know, this information is not available in REST API, but it would be good to double check with Chesnay(cc'ed). You can see the complete list of available REST commands here[1]. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.8/monitoring

Re: Getting JobExecutionException: Could not set up JobManager when trying to upload new version

2019-04-25 Thread Dawid Wysakowicz
, Dawid On 24/04/2019 07:06, Avi Levi wrote: > Might be useful for someone, Regarding this issue. it seems that > changing the uid of the operator made this mess . > > On Tue, Apr 16, 2019 at 6:31 PM Avi Levi <mailto:avi.l...@bluevoyant.com>> wrote: > > I am try

Re: assignTimestampsAndWatermarks not work after KeyedStream.process

2019-04-25 Thread Dawid Wysakowicz
Hi, Yes I think your explanation is correct. I can also recommend Seth's webinar where he talks about debugging Watermarks[1] Best, Dawid [1] https://www.ververica.com/resources/webinar/webinar/debugging-flink-tutorial On 22/04/2019 22:55, an0 wrote: > Thanks, I feel I'm getting clo

Re: Constant backpressure on flink job

2019-04-25 Thread Dawid Wysakowicz
Hi Monika, I would start with identifying the operator that causes backpressure. More information how to monitor backpressure you can find here in the docs[1]. You might also be interested in Seth's (cc'ed) webinar[2], where he also talks how to debug backpressure. Best, Dawid [1] https

Re: Create Custom Sink for DataSet

2019-04-25 Thread Dawid Wysakowicz
Hi Soheil, The equivalent of DataStream's SinkFunction in DataSet API is the mentioned OutputFormat. You can implement the OutputFormat. Best, Dawid On 21/04/2019 20:01, Soheil Pourbafrani wrote: > Hi, Using the DataStream API I could create a Custom Sink > like classRichMySqlSink e

Re: Apache Flink - CEP vs SQL detecting patterns

2019-04-25 Thread Dawid Wysakowicz
Hi, Unfortunately those are just ignored. The timed out partial matches are not emitted. Best, Dawid On 20/04/2019 19:49, M Singh wrote: > Dawid: > > So, what happens when there is a timeout - is there any value/field in > the resulting data stream that indicates that this w

Re: RichAsyncFunction Timer Service

2019-04-25 Thread Dawid Wysakowicz
callbacks. Best, Dawid On 19/04/2019 17:41, Mikhail Pryakhin wrote: > Hello, Flink community! > > It happens that I need to access a timer service in a > RichAsyncFunction implementation. I know it's normally accomplished > via StreamingRuntimeContext instance available in

Re: kafka partitions, data locality

2019-04-25 Thread Dawid Wysakowicz
Hi Smirnov, Actually there is a way to tell Flink that data is already partitioned. You can try the reinterpretAsKeyedStream[1] method. I must warn you though this is an experimental feature. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.8/dev/stream

Re: Identify orphan records after joining two streams

2019-04-25 Thread Dawid Wysakowicz
the new source interface though[1]. But as Hequn already mentioned if you use the RocksDBStateBackend, the amount of space is limited by the disk space. Moreover you could add some safety timer, that would fire every x minutes and clear the oldest entries. Best, Dawid [1] https://lists.apache.org

Re: PatternFlatSelectAdapter - Serialization issue after 1.8 upgrade

2019-04-23 Thread Dawid Wysakowicz
: StreamExecutionEnvironment.clean(pendingProjectsTag) I also opened a jira issue to fix this (FLINK-12297[1]) Best, Dawid [1] https://issues.apache.org/jira/browse/FLINK-12297 On 22/04/2019 03:06, Guowei Ma wrote: > I think you could try > StreamExecutionEnvironment.clean(pendingProje

Re: status on FLINK-7129

2019-04-23 Thread Dawid Wysakowicz
Hi Kant, I'm afraid Konstantin is right. Unfortunately AFAIK there is no active development on that issue. Best, Dawid On 22/04/2019 18:20, Konstantin Knauf wrote: > Hi Kant, > > as far as I know, no one is currently working on this. Dawid (cc) > maybe knows more. > > Chee

Re: Apache Flink - CEP vs SQL detecting patterns

2019-04-16 Thread Dawid Wysakowicz
. Best, Dawid On 12/04/2019 22:40, M Singh wrote: > Hi: > > I am looking at the documentation of the CEP and there is way to > access patterns which have timeout.  But I could  not find similar > capability in the Table and SQL interface detecting patterns.  I am > assuming that

Re: FlinkCEP and SQL?

2019-04-11 Thread Dawid Wysakowicz
The documentation should say which parts are supported and which are not. I would say the majority of important features works. Best, Dawid On 11/04/2019 12:40, Esa Heikkinen (TAU) wrote: > > Hi > >   > > Thank you. I need to read them. Does this all work in Flink 1.8 now

Re: FlinkCEP and SQL?

2019-04-11 Thread Dawid Wysakowicz
Hi Esa, Have you checked out the flink documentation for this topic[1]? Is there something you are missing from there? Also the MATCH_RECOGNIZE is described in the SQL:2016 standard[2]. For the Flink CEP library, yes it is inspired by the paper you mentioned. Best, Dawid [1] https

Re: TUMBLE function with MONTH/YEAR intervals produce milliseconds window unexpectedly

2019-03-28 Thread Dawid Wysakowicz
I did ;) but here is the link one more time: https://issues.apache.org/jira/browse/FLINK-11017?jql=project%20%3D%20FLINK%20AND%20text%20~%20Month On Thu, 28 Mar 2019, 20:48 Vinod Mehra, wrote: > Thanks Dawid! Can you please point me to a jira which tracked the fix? > > Thanks

Re: TUMBLE function with MONTH/YEAR intervals produce milliseconds window unexpectedly

2019-03-28 Thread Dawid Wysakowicz
It should be fixed since version 1.6.3. Best, Dawid [1] https://issues.apache.org/jira/browse/FLINK-11017?jql=project%20%3D%20FLINK%20AND%20text%20~%20Month On Thu, 28 Mar 2019, 19:32 Vinod Mehra, wrote: > Hi All! > > We are using: org.apache.flink:flink-table_2.11:jar:1.4.

Re: questions regarding offset

2019-03-28 Thread Dawid Wysakowicz
, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/connectors/kafka.html#kafka-consumers-offset-committing-behaviour-configuration [2] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/connectors/kafka.html#kafka-consumers-start-position-configuration On 28

Re: [DISCUSS] Introduction of a Table API Java Expression DSL

2019-03-26 Thread Dawid Wysakowicz
oducing this feature. @Jark I think we could aim to introduce the new Java DSL API in 1.9 and once we do that we could deprecate the string approach. Best, Dawid On 22/03/2019 03:36, Jark Wu wrote: > Hi Timo,   > > Sounds good to me.  > > Do you want to deprecate the string-base

Re: Flink metrics missing from UI 1.7.2

2019-03-23 Thread dawid
Padarn Wilson-2 wrote > I am running Fink 1.7.2 on Kubernetes in a setup with task manager and job > manager separate. > > I'm having trouble seeing the metrics from my Flink job in the UI > dashboard. Actually I'm using the Datadog reporter to expose most of my > metrics, but latency tracking

Re: Flink CEP pattern design question

2019-03-20 Thread Dawid Wysakowicz
alse)   .within(Time.seconds(10)) and work only with the timed out matches. Another option is you can try implementing that logic with ProcessFunction[2] Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/libs/cep.html#quantifiers [2] https://ci

Re: Can I make an Elasticsearch Sink effectively exactly once?

2019-02-21 Thread Dawid Wysakowicz
a deterministic way of generating ElasticseachId this semantic should be enough for you though. Any duplicates(by the id) should be updated on the ES side. Best, Dawid On 21/02/2019 14:26, Stephen Connolly wrote: > From how I understand it: > > https://ci.apache.org/projects/fli

Re: How to debug difference between Kinesis and Kafka

2019-02-21 Thread Dawid Wysakowicz
ones cause Watermarks might get generated after different elements as they are bound by "ProcessingTime". Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/internals/stream_checkpointing.html#checkpointing On 21/02/2019 14:42, Stephen Connolly wrote: > >

Re: How to debug difference between Kinesis and Kafka

2019-02-21 Thread Dawid Wysakowicz
It is definitely a solution ;) You should be aware of the downsides though: * you might get different results in case of reprocessing * you might drop some data as late, due to some delays in processing, if the events arrive later then the "ProcessingTime" threshold Best, Da

Re: Broadcast state before events stream consumption

2019-02-21 Thread Dawid Wysakowicz
Hi Averell, BroadcastState is a special case of OperatorState. Operator state is always kept in-memory at runtime (must fit into memory), no matter what state backend you use. Nevertheless it is snapshotted and thus fault tolerant. Best, Dawid On 21/02/2019 11:50, Averell wrote: >

Re: How to debug difference between Kinesis and Kafka

2019-02-21 Thread Dawid Wysakowicz
. I recommend reading the docs linked by Congxian, especially this section[1]. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/event_time.html#watermarks-in-parallel-streams On 19/02/2019 14:31, Stephen Connolly wrote: > Hmmm my suspicions are now quite high

Re: Forking a stream with Flink

2019-01-31 Thread Dawid Wysakowicz
Hi Daniel, The answer to you original question is you can just keyBy[1] by e.g. the machineId and then computations on KeyedStream are applied independently for each key. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/stream/operators/#datastream

Re: Why OnDataStream in flink accepts partial function but DataStream do not

2019-01-31 Thread Dawid Wysakowicz
Hi, AFAIK it clashes with def map[R: TypeInformation](mapper: MapFunction[T, R]): DataStream[R] if you use partially applied function. You can check the discussion behind the OnDataStream implementation in this jira[1]. [1] https://issues.apache.org/jira/browse/FLINK-1159 On 31/01/2019 04:10,

Re: StreamingFileSink Avro batch size and compression

2019-01-26 Thread Dawid Wysakowicz
ParquetWriterFactory<>(out ->         AvroParquetWriter.builder(out)             .withSchema(...)             .withDataMode(...)             .withCompressionCodec(...)             .build()))     .build() Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/api/java/org/apache/flink/

Re: Adding flink udf support to linkedin's portable udf framework transport

2019-01-26 Thread Dawid Wysakowicz
system for Flink's Table & SQL API will probably be updated in the near future as part of the effort of restructuring Table API & SQL for future contributions[1]. Best, Dawid [1] http://apache-flink-mailing-list-archive.1008284.n3.nabble.com/DISCUSS-FLIP-32-Restructure-flink-table-fo

Re: getting duplicate messages from duplicate jobs

2019-01-26 Thread Dawid Wysakowicz
by multiple consumers with the same group.id. I'm adding Gordon as a cc to correct me if I am wrong. Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/dev/connectors/kafka.html#kafka-consumers-offset-committing-behaviour-configuration On 23/01/2019 18:02, Avi Levi wrote

Re: ElasticSearch Connector

2019-01-16 Thread Dawid Wysakowicz
Hi Ramya, I think the problem is that you access the serializationSchema from the closure of ElasticsearchSinkFunction. Try creating ElasticsearchSinkFunction that will get the serializationSchema in ctor. If this is not the problem could you share the full stack of the error? Best, Dawid

Re: StreamingFileSink cannot get AWS S3 credentials

2019-01-16 Thread Dawid Wysakowicz
Forgot to cc ;) On 16/01/2019 08:51, Vinay Patil wrote: > Hi, > > Can someone please help on this issue. We have even tried to set > fs.s3a.impl in core-site.xml, still its not working. > > Regards, > Vinay Patil > > > On Fri, Jan 11, 2019 at 5:03 PM Taher Koitawala [via Apache Flink User >

Re: StreamingFileSink cannot get AWS S3 credentials

2019-01-16 Thread Dawid Wysakowicz
Hi, I cc Kostas who should be able to help you. Best, Dawid On 16/01/2019 08:51, Vinay Patil wrote: > Hi, > > Can someone please help on this issue. We have even tried to set > fs.s3a.impl in core-site.xml, still its not working. > > Regards, > Vinay Patil > > > O

Re: Parallelism questions

2019-01-14 Thread Dawid Wysakowicz
read here[1] As for 1 I cc'ed Gary and Till who might better answer your question. [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7/concepts/runtime.html#task-slots-and-resources Best, Dawid On 14/01/2019 15:26, Alexandru Gutan wrote: > Hi everyone! > > 1. Is th

Re: Get the savepointPath of a particular savepoint

2019-01-14 Thread Dawid Wysakowicz
Hi, The path of a savepoint is a user specified parameter, therefore it is not tracked by flink. It is up to the user to know where should the savepoint end up. As for API to check status of a savepoint you can use[1] Best, Dawid [1] https://ci.apache.org/projects/flink/flink-docs-release-1.7

<    1   2   3   4   5   >