Re: Setting app Flink logger

2020-03-10 Thread miki haiat
Which image are you using ? On Tue, Mar 10, 2020, 16:27 Eyal Pe'er wrote: > Hi Rafi, > > The file exists (and is the file from the official imageJ, please see > below). > > The user is root and it has permission. I am running in HA mode using > docker. > > > > cat /opt/flink/conf/log4j-console.p

Re: Single stream, two sinks

2020-03-01 Thread miki haiat
So you have rabitmq source and http sink? If so you can use side output in order to dump your data to db. https://ci.apache.org/projects/flink/flink-docs-stable/dev/stream/side_output.html On Sat, Feb 29, 2020, 23:01 Gadi Katsovich wrote: > Hi, > I'm new to flink and am evaluating it to replace

Re: Flink State Migration Version 1.8.2

2019-10-16 Thread miki haiat
Can you try to add the new variables as option ? On Wed, Oct 16, 2019, 17:17 ApoorvK wrote: > I have been trying to alter the current state case class (scala) which has > 250 variables, now when I add 10 more variables to the class, and when I > run > my flink application from the save point ta

Re: Should I use static database connection pool?

2019-10-16 Thread miki haiat
If it's a sink that use jdbc, why not using the flink Jdbcsink connector? On Wed, Oct 16, 2019, 17:03 Xin Ma wrote: > I have watched one of the recent Flink forward videos, Apache Flink Worst > Practices by Konstantin Knauf. The talk helps me a lot and mentions that we > should avoid using stat

Re: Reading Key-Value from Kafka | Eviction policy.

2019-09-26 Thread miki haiat
I'm sure there is several ways to implement it. Can you elaborate more on your use case ? On Fri, Sep 27, 2019, 08:37 srikanth flink wrote: > Hi, > > My data source is Kafka, all these days have been reading the values from > Kafka stream to a table. The table just grows and runs into a heap iss

Re: Flink- Heap Space running out

2019-09-26 Thread miki haiat
You can configure the task manager memory in the config.yaml file. What is the current configuration? On Thu, Sep 26, 2019, 17:14 Nishant Gupta wrote: > am running a query to join a stream and a table as below. It is running > out of heap space. Even though it has enough heap space in flink clu

Re: No field appear in Time Field name in Kibana

2019-09-05 Thread miki haiat
You need to define a date or time type in your elastic index mapping . Its not a flink issue On Wed, Sep 4, 2019 at 3:02 PM alaa wrote: > I try to run this application but there was problem when Configure an index > pattern . > There was No field appear in Time Field name in Kibana when i set in

Re: timeout error while connecting to Kafka

2019-08-25 Thread miki haiat
g/projects/flink/flink-docs-stable/ops/deployment/docker.html) > on a remote machine and to submit a job that supposed to communicate with > Kafka, but still I cannot access the topic. > > > > > > Best regards > > Eyal Peer */ *Data Platform Developer > > > &g

Re: timeout error while connecting to Kafka

2019-08-25 Thread miki haiat
t; > Eyal Peer */ *Data Platform Developer > > > > *From:* Eyal Pe'er > *Sent:* Sunday, August 25, 2019 2:20 PM > *To:* miki haiat > *Cc:* user@flink.apache.org > *Subject:* RE: timeout error while connecting to Kafka > > > > Hi, > > I removed that

Re: Using shell environment variables

2019-08-24 Thread miki haiat
Did you register your system environment parameter ? You can find here several ways to use configuration data [1] 1. https://ci.apache.org/projects/flink/flink-docs-stable/dev/best_practices.html On Sat, Aug 24, 2019, 20:26 Abhishek Jain wrote: > Hi! > > I am using a library that depends on a

Re: timeout error while connecting to Kafka

2019-08-22 Thread miki haiat
> > > > org.apache.flink > > flink-clients_2.10 > > 1.1.4 > > > > > > org.apache.flink > > flink-connector-kafka_2.11 > > 1.7.0 > > >

Re: timeout error while connecting to Kafka

2019-08-22 Thread miki haiat
Can you double check that the kafka instance is up ? The code looks fine. Best, Miki On Thu, Aug 22, 2019 at 10:45 AM Eyal Pe'er wrote: > Hi, > > I'm trying to consume events using Apache Flink. > > The code is very basic, trying to connect the topic split words by space > and print it to the

Re: Recovery from job manager crash using check points

2019-08-19 Thread miki haiat
Wich kind of deployment system are you using, Standalone ,yarn ... Other ? On Mon, Aug 19, 2019, 18:28 wrote: > Hi, > > > > I can use check points to recover Flink states when a task manger crashes. > > > > I can not use check points to recover Flink states when a job manger > crashes. > > > > D

Re: Capping RocksDb memory usage

2019-08-07 Thread miki haiat
I think using metrics exporter is the easiest way [1] https://ci.apache.org/projects/flink/flink-docs-stable/monitoring/metrics.html#rocksdb On Wed, Aug 7, 2019, 20:28 Cam Mach wrote: > Hello everyone, > > What is the most easy and efficiently way to cap RocksDb's memory usage? > > Thanks, > C

Re: Does RocksDBStateBackend need a separate RocksDB service?

2019-08-07 Thread miki haiat
There is no need to add an external RocksDB instance . *The RocksDBStateBackend holds in-flight data in a RocksDB database that is (per default) stored in the TaskManager data directories. * [1] https://ci.apache.org/projects/flink/flink-docs-stable/ops/state/state_backen

[bug ?] PrometheusPushGatewayReporter register more then one JM

2019-08-06 Thread miki haiat
We have standalone cluster with PrometheusPushGatewayReporter conflagration. its seems like we cant register more then one JM to Prometheus because of naming uniqueness. WARN org.apache.flink.metrics.prometheus.PrometheusPushGatewayReporter - There was a problem registering metric numRunni

Re: From Kafka Stream to Flink

2019-07-20 Thread miki haiat
Can you elaborate more about your use case . On Sat, Jul 20, 2019 at 1:04 AM Maatary Okouya wrote: > Hi, > > I am a user of Kafka Stream so far. However, because i have been face with > several limitation in particular in performing Join on KTable. > > I was wondering what is the appraoch in F

Re: failed checkpoint with metadata timeout exception

2019-07-18 Thread miki haiat
; On Thu, Jul 18, 2019 at 3:49 PM miki haiat wrote: > >> Can you share your logs >> >> >> On Thu, Jul 18, 2019 at 3:22 PM Yitzchak Lieberman < >> yitzch...@sentinelone.com> wrote: >> >>> Hi. >>> >>> I have flink a applicati

Re: failed checkpoint with metadata timeout exception

2019-07-18 Thread miki haiat
Can you share your logs On Thu, Jul 18, 2019 at 3:22 PM Yitzchak Lieberman < yitzch...@sentinelone.com> wrote: > Hi. > > I have flink a application that produces to kafka with 3 brokers. > When I add 2 brokers that are not up yet it fails the checkpoint (a key in > s3) due to timeout error. > >

Re: Flink and CDC

2019-07-18 Thread miki haiat
I actually thinking about this option as well . Im assuming that the correct way to implement it , is to integrate debezium embedded to source function ? [1] https://github.com/debezium/debezium/tree/master/debezium-embedded On Wed, Jul 17, 2019 at 7:08 PM Flavio Pompermaier wrote: > Hi

Re: Running Flink cluster via Marathon

2019-07-14 Thread miki haiat
How many Job manager did you configure ? On Mon, Jul 15, 2019, 07:11 Marzieh Ghasemy wrote: > Hello I have a Mesos cluster of two master and three slaves, I configured > Marathon and Zookeeper. My Zookeeper cluster has five nodes. When I run > Flink Json file via Marathon, it is run, but I ca

Re: Read file from S3 and write to kafka

2019-06-04 Thread miki haiat
You can use the DataSet API to parse files from S3. https://ci.apache.org/projects/flink/flink-docs-release-1.8/dev/batch/#data-sources https://ci.apache.org/projects/flink/flink-docs-stable/ops/deployment/aws.html#s3-simple-storage-service And then parsed it and send it to kafka. On Tue, Ju

Re: Propagating delta from window upon trigger

2019-05-18 Thread miki haiat
Can you elaborate more what is you use case ? On Sat, May 18, 2019 at 12:47 AM Nikhil Goyal wrote: > Hi guys, > > Is there a way in Flink to only propagate the changes which happened in > the window's state rather than dumbing the contents of the window again and > again upon trigger? > > Than

Re: flink 1.7 HA production setup going down completely

2019-05-07 Thread miki haiat
Which flink version are you using? I had similar issues with 1.5.x On Tue, May 7, 2019 at 2:49 PM Manjusha Vuyyuru wrote: > Hello, > > I have a flink setup with two job managers coordinated by zookeeper. > > I see the below exception and both jobmanagers are going down: > > 2019-05-07 08:29:13,

Re: connecting two streams flink

2019-01-29 Thread miki haiat
If c1 and c2 are listing to the same topic they will consume the same data . so i cant understand this > these two streams one(c2) is fast and other(c1) On Tue, Jan 29, 2019 at 2:44 PM Selvaraj chennappan < selvarajchennap...@gmail.com> wrote: > Team, > > I have two kafka consumer for s

Re: Forking a stream with Flink

2019-01-29 Thread miki haiat
Im not sure if i got your question correctly, can you elaborate more on your use case

Re: Kafka stream fed in batches throughout the day

2019-01-21 Thread miki haiat
In flink you cant read data from kafka in Dataset API (Batch) And you dont want to mess with start and stop your job every few hours. Can you elaborate more on your use case , Are you going to use KeyBy , is thire any way to use trigger ... ? On Mon, Jan 21, 2019 at 4:43 PM Jonny Graham wrote:

Re: How can I make HTTP requests from an Apache Flink program?

2019-01-15 Thread miki haiat
Can you share more which use case are you trying to implement ? On Tue, Jan 15, 2019 at 2:02 PM wrote: > Hi all, > > > > I was wondering if anybody has any recommendation over making HTTP > requests from Flink to another service. > > On the long term we are looking for a solution that is both

Flink error reading file over network (Windows)

2019-01-02 Thread miki haiat
Hi, Im trying to read a csv file from windows shard drive. I tried numbers option but i failed. I cant find an option to use SMB format, so im assuming that create my own input format is the way to achieve that ? What is the correct way to read file from windows network ?. Thanks, Miki

Re: using updating shared data

2019-01-01 Thread miki haiat
Im trying to understand your use case. What is the source of the data ? FS ,KAFKA else ? On Tue, Jan 1, 2019 at 6:29 PM Avi Levi wrote: > Hi, > I have a list (couple of thousands text lines) that I need to use in my > map function. I read this article about broadcasting variables >

Re: getting Timeout expired while fetching topic metadata

2018-12-24 Thread miki haiat
Hi Avi, Can you try to add this properties props.put(CommonClientConfigs.SECURITY_PROTOCOL_CONFIG, "SSL"); Thanks, Miki On Mon, Dec 24, 2018 at 8:19 PM Avi Levi wrote: > Hi all, > very new to flink so my apology if it seems trivial. > We deployed flink on gcloud > I am trying to connect to ka

Re: Query big mssql Data Source [Batch]

2018-12-06 Thread miki haiat
sks: > >1. SELECT BETWEEN 3 and 50 >2. SELECT BETWEEN 51 and 100 >3. SELECT BETWEEN 101 and 150 >4. SELECT BETWEEN 151 and 200 >5. SELECT BETWEEN 201 and 250 >6. SELECT BETWEEN 251 and 300 > > > On Thu, Dec 6,

Re: Query big mssql Data Source [Batch]

2018-12-06 Thread miki haiat
hi Flavio , This is the query that im trying to coordinate > .setQuery("SELECT a, b, c, \n" + > "FROM dbx.dbo.x as tls\n"+ > "WHERE tls.a BETWEEN ? and ?" > > And this is the way im trying to parameterized ParameterValuesProvider pramProvider = new NumericBetweenParametersProvide

Re: Query big mssql Data Source [Batch]

2018-12-05 Thread miki haiat
gt; > On Tue, 4 Dec 2018, 17:31 miki haiat >> HI , >> I want to query some sql table that contains ~80m rows. >> >> There is a few ways to do that and i wonder what is the best way to do >> that . >> >> >>1. Using JDBCINPUTFORMAT -> conve

Query big mssql Data Source [Batch]

2018-12-04 Thread miki haiat
HI , I want to query some sql table that contains ~80m rows. There is a few ways to do that and i wonder what is the best way to do that . 1. Using JDBCINPUTFORMAT -> convert to dataset and output it without doing any logic in the dataset, passing the full query in the JDBCINPUTFORM

Re: Looking for example for bucketingSink / StreamingFileSink

2018-12-03 Thread miki haiat
HI Avi , Im assuming that the cause of the "pending" file is because the checkpoint isn't finished successfully [1] Can you try to change the checkpoint time to 1 min as well . Thanks, Miki [1] https://github.com/apache/flink/blob/master/flink-connectors/flink-connector-filesystem/src/main/

Re: where can I see logs from code

2018-11-25 Thread miki haiat
You can see the logs in the webUI. If you click on the Task manager tab you can find the logs http://SERVERADD/#/taskmanager/TM_ID/log On Sun, Nov 25, 2018 at 12:11 PM Avi Levi wrote: > Hi, > Where can I see the logs written by the app code (i.e by the app > developer) ? > > BR > Avi >

Re: Logging Kafka during exceptions

2018-11-21 Thread miki haiat
wrote: > Json is sent into Kafka > > > Regards, > Scott > > SCOTT SUE > CHIEF TECHNOLOGY OFFICER > > Support Line : +44(0) 2031 371 603 > Mobile : +852 9611 3969 > > 9/F, 33 Lockhart Road, Wan Chai, Hong Kong > www.celer-tech.com > > > > > >

Re: Could not extract key Exception only on runtime not in dev environment

2018-11-20 Thread miki haiat
What r.id Value ? Are you sure that is not null ? Miki. On Tue, 20 Nov 2018, 17:26 Avi Levi I am running flink locally on my machine , I am getting the exception > below when reading from kafka topic. when running from the ide (intellij) > it is running perfectly. however when I deploy my jar

Re: Deadlock happens when sink to mysql

2018-11-19 Thread miki haiat
can you share your entire code please On Mon, Nov 19, 2018 at 4:03 PM 徐涛 wrote: > Hi Experts, > I use the following sql, and sink to mysql, > select > > album_id, date > count(1) > from > coupon_5_discount_date_conv > group by > album_id, date; > > > when sink to mysql, the f

Re: Standalone HA cluster: Fatal error occurred in the cluster entrypoint.

2018-11-16 Thread miki haiat
I "solved" this issue by cleaning the zookeeper information and start the cluster again all the the checkpoint and job graph data will be erased and basacly you will start a new cluster... It's happened to me allot on a 1.5.x On a 1.6 things are running perfect . I'm not sure way this error is bac

Re: Get savepoint status fails - Flink 1.6.2

2018-11-15 Thread miki haiat
Can you share some logs On Thu, Nov 15, 2018 at 10:46 AM PedroMrChaves wrote: > Hello, > > I've tried with different (jobId, triggerId) pairs but it doesn't work. > > > Regards, > Pedro Chaves. > > > > - > Best Regards, > Pedro Chaves > -- > Sent from: > http://apache-flink-user-mailing-list

Re: running flink job cluster on kubernetes with HA

2018-11-13 Thread miki haiat
Its looks like in the next version 1.7 you can achieve HA on Kubernetes without zookeeper . Anyway for now you can configure one zookeeper path to save the data , the path should be some distribute FS like HDFS ,S3 fs. Thanks , Miki On Tue, No

Re: Failed to fetch BLOB - IO Exception

2018-10-23 Thread miki haiat
How is your cluster configured ? What is the Checkpoint/save point directory configuration ? On Tue, Oct 23, 2018 at 8:00 AM Manjusha Vuyyuru wrote: > Hello All, > > I have a job which fails lets say after every 14 days with IO Exception, > failed to fetch blob. > I submitted the job using co

Re: Flink JobManager is not starting when running on a standalone cluster

2018-10-22 Thread miki haiat
I think it`s related to this issue https://issues.apache.org/jira/browse/FLINK-10011 On Mon, Oct 22, 2018 at 1:52 PM Kumar Bolar, Harshith wrote: > Hi all, > > > > We run Flink on a five node cluster – three task managers, two job > managers. One of the job manager running on flink2-0 node is

Re: Flink Table API and table name

2018-10-16 Thread miki haiat
Im not sure if it will solve this issue but can you try to register the your catalog [1] 1. https://ci.apache.org/projects/flink/flink-docs-release-1.6/dev/table/common.html#register-an-external-catalog On Tue, Oct 16, 2018 at 11:40 AM Flavio Pompermaier wrote: > Hi to all, > in my job I'm try

Re: Can't start taskmanager in Minikube

2018-10-16 Thread miki haiat
Did you execute this command ? Note: If using MiniKube please make sure to execute minikube ssh 'sudo ip > link set docker0 promisc on' before deploying a Flink cluster. Otherwise > Flink components are not able to self reference themselves through a > Kubernetes service. On Tue, Oct 16, 2018 at

Re: I want run flink program in ubuntu x64 Mult Node Cluster what is configuration?

2018-09-30 Thread miki haiat
The easiest way to tun it without adding user and root permission is to run it with *sudo command* *sudo /start-cluster.sh* If you want to run high availability cluster you need to follow those instruction [1] 1. https://ci.apache.org/projects/flink/flink-docs-release-1.6/ops/jobmanager_high_a

Re: error closing kafka

2018-09-23 Thread miki haiat
What are you trying to do , can you share some code ? This is the reason for the exeption Proceeding to force close the producer since pending requests could not be completed within timeout 9223372036854775807 ms. On Mon, 24 Sep 2018, 9:23 yuvraj singh, <19yuvrajsing...@gmail.com> wrote: > Hi a

Re: Server side error: Cannot find required BLOB at /tmp/blobStore

2018-09-11 Thread miki haiat
/tmp/blobStore Is it the path for checkpoints/savepoints storage ? On Tue, 11 Sep 2018, 10:01 Raja.Aravapalli, wrote: > Hi, > > > > My Flink application which reads from Kafka and writes to HDFS is failing > repeatedly with below exception: > > > > Caused by: java.io.IOException: Server side e

Re: Unable to start Flink HA cluster with Zookeeper

2018-08-21 Thread miki haiat
First of all try with FQD or full ip. Also in order to run HA cluster you need to make sure that you have password less ssh access to your slaves and master communication. . On Tue, Aug 21, 2018 at 4:15 PM mozer wrote: > I am trying to install a Flink HA cluster (Zookeeper mode) but the task

Re: connection failed when running flink in a cluster

2018-08-06 Thread miki haiat
Did you start job manager and task manager on the same resbery pi ? On Mon, 6 Aug 2018, 12:01 Felipe Gutierrez, wrote: > Hello everyone, > > I am trying to run Flink on Raspberry Pis. My first test for word count in > a single node worked. I just have to decrease the Heap memory of the > jobmana

Elasticsearch 6.3.x connector

2018-07-16 Thread miki haiat
HI , I just wondered what is to status of the 6.3.x elastic connector. flink-connector-elasticsearch-base_2.11 has elastic 6.3.1 dependencies . Documentation mention 5.3 as the stable version el

Re: flink JPS result changes

2018-07-11 Thread miki haiat
Flink 6 changed the execution model compactly https://cwiki.apache.org/confluence/pages/viewpage.action?pageId=65147077 https://docs.google.com/document/d/1zwBP3LKnJ0LI1R4-9hLXBVjOXAkQS5jKrGYYoPz-xRk/edit#heading=h.giuwq6q8d23j On Wed, Jul 11, 2018 at 5:09 PM Will Du wrote: > Hi folks > Do we

Re: How to load data in flink memory?

2018-07-08 Thread miki haiat
If you want to use earlier or other data and process it. You can use process function process_function Also loading data in to memory isn't a good idea , you can crash the task manage

Re: Passing type information to JDBCAppendTableSink

2018-07-01 Thread miki haiat
can you share the full code . On Sun, Jul 1, 2018 at 12:49 PM chrisr123 wrote: > > I'm trying to determine if I'm specifying type information properly when > doing an INSERT using > the JDBCAppendTableSink API. Specifically, how do I specify timestamp and > date types? It looks like > I need t

Writing csv to Hadoop Data stream

2018-06-11 Thread miki haiat
Hi, Im trying to stream data to Haddop as a csv . In batch processing i can use HadoopOutputFormat like that ( example/WordCount.java

Re: File does not exist prevent from Job manager to start .

2018-06-06 Thread miki haiat
a submit job call. > > Cheers, > Till > > On Mon, Jun 4, 2018 at 12:31 PM miki haiat wrote: > >> HI Till, >> Iv`e managed to do reproduce it. >> Full log faild_jm.log >> <https://gist.githubusercontent.com/miko-code/e634164404354c4c590be84292fd8cb2/

Re: Writing stream to Hadoop

2018-06-05 Thread miki haiat
OMG i missed it ... Thanks, MIki On Tue, Jun 5, 2018 at 1:30 PM Chesnay Schepler wrote: > This particular version of the method is deprecated, use > enableCheckpointing(long > checkpointingInterval) instead. > > On 05.06.2018 12:19, miki haiat wrote: > > I saw t

Re: Writing stream to Hadoop

2018-06-05 Thread miki haiat
as > > On Jun 5, 2018, at 11:14 AM, miki haiat wrote: > > Im trying to write some data to Hadoop by using this code > > The state backend is set without time > > StateBackend sb = new > FsStateBackend("hdfs://***:9000/flink/my_city/checkpoints"); > env

Writing stream to Hadoop

2018-06-05 Thread miki haiat
Im trying to write some data to Hadoop by using this code The state backend is set without time StateBackend sb = new FsStateBackend("hdfs://***:9000/flink/my_city/checkpoints"); env.setStateBackend(sb); BucketingSink> sink = new BucketingSink<>("hdfs://:9000/mycity/raw"); sink.setBu

Re: TaskManager use more memory than Xmx

2018-06-04 Thread miki haiat
Which flink version ? I had the same issue on 1.4.2 . On Mon, Jun 4, 2018 at 2:14 PM Szczypiński, S. (Szymon) < szymon.szczypin...@ingbank.pl> wrote: > Hi, > > I have a problem with TaskManagers in my standalone cluster. > > > > My problem is that my host have 32GB RAM memory. TaskManager have

Re: File does not exist prevent from Job manager to start .

2018-06-04 Thread miki haiat
elete the stored blobs on the HA storage. Could > you try to reproduce the problem and then send us the logs on DEBUG level? > Please also check before shutting the cluster down, that the files were > there. > > Cheers, > Till > > On Sun, Jun 3, 2018 at 1:10 PM miki haiat

Re: File does not exist prevent from Job manager to start .

2018-06-03 Thread miki haiat
al run of the job. So if > you can reproduce the problem, then this log would be very helpful. > > Cheers, > Till > > On Thu, May 31, 2018 at 6:14 PM, miki haiat wrote: > >> Hi, >> >> Im having some wierd issue with the JM recovery , >> I using HDFS an

File does not exist prevent from Job manager to start .

2018-05-31 Thread miki haiat
Hi, Im having some wierd issue with the JM recovery , I using HDFS and ZOOKEEPER for HA stand alone cluster . Iv stop the cluster change some parameters in the flink conf (Memory). But now when i start the cluster again im having an error that preventing from JM to start. somehow the checkpoint

HA stand alone cluster error

2018-05-29 Thread miki haiat
i had some catastrofic eroror > > ERROR org.apache.flink.runtime.entrypoint.ClusterEntrypoint - > Fatal error occurred in the cluster entrypoint. > org.apache.flink.util.FlinkException: Failed to recover job > a048ad572c9837a400eca20cd55241b6. > File does not exist: > /flink_1.5/ha/beam1/

Re: data enrichment with SQL use case

2018-05-15 Thread miki haiat
;>>> every stream record. This should be the easier implementation but it will >>>> send one query to the DB for each streamed record. >>>> 2) Replicate the meta data into Flink state and join the streamed >>>> records with the state. This solution is more com

Default zookeeper

2018-05-13 Thread miki haiat
When downloading the the flink source in order to run it local thire is a zookeper script and start-zookeeper-quorum script . Is thire any difference between the default zookeeper installation lets say in Ubuntu and the zookeeper that come with flink ? thanks, MIki

JM/TM Disassociated

2018-04-29 Thread miki haiat
Hi, I have some simple elesticsearch sink on mesos with 6 TM , but for some reason after few hours JM/TM is Disassociated and killed all other TM as well . this is were everything collapse 2018-04-29 08:21:00,457 WARN akka.remote.ReliableDeliverySupervisor - Associati

elasticsearch5 , java.lang.NoClassDefFoundError on mesos

2018-04-24 Thread miki haiat
Hi , Im having some weird issue when running some stream job to ELK . The job i starting fine but after few hours im getting this exception and the TM/JB is crashed . this is the config for the elesticserch sink , may by 1 sec flush can cause the deadlock ?? config.put("bulk.flush.max.act

Trigger state clear

2018-04-24 Thread miki haiat
Hi I have some issue possibly memory issue that causing the task manager to crash . full code : https://gist.github.com/miko-code/6d7010505c3cb95be122364b29057237 I defined fire_and_purge on element and also evictor so state should be very small ... Any suggestion how figure this issue ? T

Re: How to run flip-6 on mesos

2018-04-24 Thread miki haiat
gt; [1] https://issues.apache.org/jira/browse/FLINK-8176 > [2] http://people.apache.org/~trohrmann/flink-1.5.0-rc1/ > > > On Tue, Apr 24, 2018 at 9:27 AM, miki haiat wrote: > >> The problem is that the Web UI hasn't started at all >> Im using the sane config file

Re: How to run flip-6 on mesos

2018-04-24 Thread miki haiat
bin/flink run -m hostname:6123 examples/streaming/WordCount.jar > > where 6123 is the jobmanager.rpc.port. > > Let me know if any of these work for you > > Best, > Gary > > > On Tue, Apr 24, 2018 at 8:55 AM, miki haiat wrote: > >> NO :) ... >> I usuall

Re: How to run flip-6 on mesos

2018-04-23 Thread miki haiat
t; allocated dynamically. > > Best, > Gary > > > On Tue, Apr 24, 2018 at 8:31 AM, miki haiat wrote: > >> >> HI, >> Im trying to tun flip-6 on mesos but its not clear to me what is the >> correct way to do it . >> >> I run the session script a

Re: KafkaJsonTableSource purpose

2018-04-23 Thread miki haiat
HI , Assuming that your looking for streaming use case , i think this is a better approach 1. Send Avro from logstash ,better performance. 2. Deserialize it to POJO . 3. Do logic... On Mon, Apr 23, 2018 at 4:03 PM, Lehuede sebastien wrote: > Hi Guys, > > I'm actually trying to un

How to run flip-6 on mesos

2018-04-23 Thread miki haiat
HI, Im trying to tun flip-6 on mesos but its not clear to me what is the correct way to do it . I run the session script and i can see that new framework has been created in mesos but the task manager hasn't been created running taskmanager-flip6.sh throw null pointer ... what is the correct

Re: data enrichment with SQL use case

2018-04-16 Thread miki haiat
ml > > — Ken > > > On Apr 15, 2018, at 12:15 PM, miki haiat wrote: > > Hi, > > I have a case of meta data enrichment and im wondering if my approach is > the correct way . > >1. input stream from kafka. >2. MD in msSQL . >3. map to new pojo &g

data enrichment with SQL use case

2018-04-15 Thread miki haiat
Hi, I have a case of meta data enrichment and im wondering if my approach is the correct way . 1. input stream from kafka. 2. MD in msSQL . 3. map to new pojo I need to extract a key from the kafka stream and use it to select some values from the sql table . SO i thought to use t

Re: Re: java.lang.Exception: TaskManager was lost/killed

2018-04-09 Thread miki haiat
Javier "adding the jar file to the /lib path of every task manager" are you moving the job jar to the* ~/flink-1.4.2/lib path* ? On Mon, Apr 9, 2018 at 12:23 PM, Javier Lopez wrote: > Hi, > > We had the same metaspace problem, it was solved by adding the jar file to > the /lib path of every ta

Re: Flink override config params (Docker)

2018-04-09 Thread miki haiat
You can mount the conf folder and ovride the conf file. On Mon, 9 Apr 2018, 14:04 Pavel Ciorba, wrote: > Hi everyone > > Is there a way to override the *conf/flink-conf.yaml* of the Flink Docker > container? > > I need to specify some params such as: > state.backend > state.backend.fs.checkpoint

Re: Temporary failure in name resolution

2018-04-03 Thread miki haiat
>> too late such that the state becomes too big. >> >> Regards, >> Timo >> >> >> Am 03.04.18 um 08:26 schrieb miki haiat: >> >> i tried to run flink on kubernetes and as stand alone HA cluster and on >> both cases

Re: Connect more than stream!!

2018-03-22 Thread miki haiat
You can join streams http://training.data-artisans.com/exercises/eventTimeJoin.html On Thu, 22 Mar 2018, 11:36 Puneet Kinra, wrote: > Hi > > Is there any way of connecting multiple streams(more than one) in flink > > -- > *Cheers * > > *Puneet Kinra* > > *Mobile:+918800167808 | Skype : puneet.

Re: flink on mesos

2018-03-18 Thread miki haiat
dergaard > > > Den 18. mar. 2018 kl. 16.18 skrev miki haiat : > > > Hi , > > Im trying to run flink on mesos iv installed mesos and marathon > successfully but im unable to create flink job/task manager > > im running this command but mesos wont start any task >

flink on mesos

2018-03-18 Thread miki haiat
Hi , Im trying to run flink on mesos iv installed mesos and marathon successfully but im unable to create flink job/task manager im running this command but mesos wont start any task ./mesos-appmaster-flip6-session.sh -n 1 i cant figure out the proper way to run flink on mesos

Change conf.yaml properties flink docker

2018-03-15 Thread miki haiat
HI , I want to change some flink-conf (jvm parameters ) properties that are default configured In the latest docker image . The only option that i can think of is creating custom image that will overwrite the current flink-conf file with new properties ? I basically want to create kubern

akka.remote.ReliableDeliverySupervisor Temporary failure in name resolution

2018-03-06 Thread miki haiat
Hi , Im running flink jobs on kubernetes after a day or so. the task manager and job managerlosing connection and i have to restart earthing . Im assuming that one of the pods crashed and when now pod start he cant find the job manager ? Also i saw that is an Akka issue... and it wiil be fi

Fwd: Global window keyBy

2018-02-05 Thread miki haiat
ate#clear()` > call and it "Removes the value mapped under the current key.”. So other > keys should remain unmodified. > > I hope this solves your problem/question? > > Piotrek > > On 4 Feb 2018, at 15:39, miki haiat wrote: > > Im using trigger and a gui

Global window keyBy

2018-02-04 Thread miki haiat
Im using trigger and a guid in order to key stream . I have some problem to understand how to clear the window . - FIRE_AND_PURGE in trigger will remove the keyd data only ? if fire and purge is removing all the data then i need to implement it more like this example https://github.