You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@kafka.apache.org by Владислав Виниченко <ak...@gmail.com> on 2021/09/01 15:39:49 UTC

kafka producer hangs

ERROR [kafka-producer-network-thread | producer-2]
c.o.p.a.s.CalculatorAdapter [CalculatorAdapter.java:285]
Cannot send outgoingDto with decision id = 46d1-9491-123ce9c7a916 in kafka:
org.springframework.kafka.core.KafkaProducerException: Failed to send;
nested exception is org.apache.kafka.common.errors.TimeoutException:
Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
creation
  at
org.springframework.kafka.core.KafkaTemplate.lambda$buildCallback$4(KafkaTemplate.java:602)
  at
org.springframework.kafka.core.DefaultKafkaProducerFactory$CloseSafeProducer$1.onCompletion(DefaultKafkaProducerFactory.java:871)
  at
org.apache.kafka.clients.producer.KafkaProducer$InterceptorCallback.onCompletion(KafkaProducer.java:1356)
  at
org.apache.kafka.clients.producer.internals.ProducerBatch.completeFutureAndFireCallbacks(ProducerBatch.java:231)
  at
org.apache.kafka.clients.producer.internals.ProducerBatch.done(ProducerBatch.java:197)
  at
org.apache.kafka.clients.producer.internals.Sender.failBatch(Sender.java:676)
  at
org.apache.kafka.clients.producer.internals.Sender.sendProducerData(Sender.java:380)
  at
org.apache.kafka.clients.producer.internals.Sender.runOnce(Sender.java:323)
  at org.apache.kafka.clients.producer.internals.Sender.run(Sender.java:239)
  at java.base/java.lang.Thread.run(Thread.java:834)
Caused by: org.apache.kafka.common.errors.TimeoutException:
Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
creation

I have been fighting with him for the second week.
Revised a bunch of fix recipes, but none of the recipes helped.
My program sends messages about 60 kilobytes in size, but they do not reach
the kafka server.
The entire java application log is filled with exceptions of this kind.


-- 
С уважением, Влад Виниченко.

Re: kafka producer hangs

Posted by Jason Turim <ja...@signalvine.com>.
have you seen this?


https://stackoverflow.com/questions/46649748/kafka-producer-timeoutexception-expiring-1-records

jt

On Wed, Sep 1, 2021, 10:42 PM Luke Chen <sh...@gmail.com> wrote:

> Hi Владислав,
> How do you know "they do not reach the kafka server."?
>
> We need to know your configs on producer and server side so that we can
> help you.
> Also, you might be able to turn on TRACE or DEBUG log on producer and
> server for troubleshooting.
> If possible, a complete log would be better than this partial exception
> log.
>
> Thank you.
> Luke
>
> On Wed, Sep 1, 2021 at 11:52 PM Владислав Виниченко <ak...@gmail.com>
> wrote:
>
> > Does anyone knows fix for this?
> >
> > ср, 1 сент. 2021 г. в 18:39, Владислав Виниченко <ak...@gmail.com>:
> >
> > > ERROR [kafka-producer-network-thread | producer-2]
> > > c.o.p.a.s.CalculatorAdapter [CalculatorAdapter.java:285]
> > > Cannot send outgoingDto with decision id = 46d1-9491-123ce9c7a916 in
> > > kafka:
> > > org.springframework.kafka.core.KafkaProducerException: Failed to send;
> > > nested exception is org.apache.kafka.common.errors.TimeoutException:
> > > Expiring 1 record(s) for save-request-0:604351 ms has passed since
> batch
> > > creation
> > >   at
> > >
> >
> org.springframework.kafka.core.KafkaTemplate.lambda$buildCallback$4(KafkaTemplate.java:602)
> > >   at
> > >
> >
> org.springframework.kafka.core.DefaultKafkaProducerFactory$CloseSafeProducer$1.onCompletion(DefaultKafkaProducerFactory.java:871)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.KafkaProducer$InterceptorCallback.onCompletion(KafkaProducer.java:1356)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.internals.ProducerBatch.completeFutureAndFireCallbacks(ProducerBatch.java:231)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.internals.ProducerBatch.done(ProducerBatch.java:197)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.internals.Sender.failBatch(Sender.java:676)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.internals.Sender.sendProducerData(Sender.java:380)
> > >   at
> > >
> >
> org.apache.kafka.clients.producer.internals.Sender.runOnce(Sender.java:323)
> > >   at
> > > org.apache.kafka.clients.producer.internals.Sender.run(Sender.java:239)
> > >   at java.base/java.lang.Thread.run(Thread.java:834)
> > > Caused by: org.apache.kafka.common.errors.TimeoutException:
> > > Expiring 1 record(s) for save-request-0:604351 ms has passed since
> batch
> > > creation
> > >
> > > I have been fighting with him for the second week.
> > > Revised a bunch of fix recipes, but none of the recipes helped.
> > > My program sends messages about 60 kilobytes in size, but they do not
> > > reach the kafka server.
> > > The entire java application log is filled with exceptions of this kind.
> > >
> > >
> > > --
> > > С уважением, Влад Виниченко.
> > >
> >
>

Re: kafka producer hangs

Posted by Luke Chen <sh...@gmail.com>.
Hi Владислав,
How do you know "they do not reach the kafka server."?

We need to know your configs on producer and server side so that we can
help you.
Also, you might be able to turn on TRACE or DEBUG log on producer and
server for troubleshooting.
If possible, a complete log would be better than this partial exception log.

Thank you.
Luke

On Wed, Sep 1, 2021 at 11:52 PM Владислав Виниченко <ak...@gmail.com>
wrote:

> Does anyone knows fix for this?
>
> ср, 1 сент. 2021 г. в 18:39, Владислав Виниченко <ak...@gmail.com>:
>
> > ERROR [kafka-producer-network-thread | producer-2]
> > c.o.p.a.s.CalculatorAdapter [CalculatorAdapter.java:285]
> > Cannot send outgoingDto with decision id = 46d1-9491-123ce9c7a916 in
> > kafka:
> > org.springframework.kafka.core.KafkaProducerException: Failed to send;
> > nested exception is org.apache.kafka.common.errors.TimeoutException:
> > Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
> > creation
> >   at
> >
> org.springframework.kafka.core.KafkaTemplate.lambda$buildCallback$4(KafkaTemplate.java:602)
> >   at
> >
> org.springframework.kafka.core.DefaultKafkaProducerFactory$CloseSafeProducer$1.onCompletion(DefaultKafkaProducerFactory.java:871)
> >   at
> >
> org.apache.kafka.clients.producer.KafkaProducer$InterceptorCallback.onCompletion(KafkaProducer.java:1356)
> >   at
> >
> org.apache.kafka.clients.producer.internals.ProducerBatch.completeFutureAndFireCallbacks(ProducerBatch.java:231)
> >   at
> >
> org.apache.kafka.clients.producer.internals.ProducerBatch.done(ProducerBatch.java:197)
> >   at
> >
> org.apache.kafka.clients.producer.internals.Sender.failBatch(Sender.java:676)
> >   at
> >
> org.apache.kafka.clients.producer.internals.Sender.sendProducerData(Sender.java:380)
> >   at
> >
> org.apache.kafka.clients.producer.internals.Sender.runOnce(Sender.java:323)
> >   at
> > org.apache.kafka.clients.producer.internals.Sender.run(Sender.java:239)
> >   at java.base/java.lang.Thread.run(Thread.java:834)
> > Caused by: org.apache.kafka.common.errors.TimeoutException:
> > Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
> > creation
> >
> > I have been fighting with him for the second week.
> > Revised a bunch of fix recipes, but none of the recipes helped.
> > My program sends messages about 60 kilobytes in size, but they do not
> > reach the kafka server.
> > The entire java application log is filled with exceptions of this kind.
> >
> >
> > --
> > С уважением, Влад Виниченко.
> >
>

Re: kafka producer hangs

Posted by Владислав Виниченко <ak...@gmail.com>.
Does anyone knows fix for this?

ср, 1 сент. 2021 г. в 18:39, Владислав Виниченко <ak...@gmail.com>:

> ERROR [kafka-producer-network-thread | producer-2]
> c.o.p.a.s.CalculatorAdapter [CalculatorAdapter.java:285]
> Cannot send outgoingDto with decision id = 46d1-9491-123ce9c7a916 in
> kafka:
> org.springframework.kafka.core.KafkaProducerException: Failed to send;
> nested exception is org.apache.kafka.common.errors.TimeoutException:
> Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
> creation
>   at
> org.springframework.kafka.core.KafkaTemplate.lambda$buildCallback$4(KafkaTemplate.java:602)
>   at
> org.springframework.kafka.core.DefaultKafkaProducerFactory$CloseSafeProducer$1.onCompletion(DefaultKafkaProducerFactory.java:871)
>   at
> org.apache.kafka.clients.producer.KafkaProducer$InterceptorCallback.onCompletion(KafkaProducer.java:1356)
>   at
> org.apache.kafka.clients.producer.internals.ProducerBatch.completeFutureAndFireCallbacks(ProducerBatch.java:231)
>   at
> org.apache.kafka.clients.producer.internals.ProducerBatch.done(ProducerBatch.java:197)
>   at
> org.apache.kafka.clients.producer.internals.Sender.failBatch(Sender.java:676)
>   at
> org.apache.kafka.clients.producer.internals.Sender.sendProducerData(Sender.java:380)
>   at
> org.apache.kafka.clients.producer.internals.Sender.runOnce(Sender.java:323)
>   at
> org.apache.kafka.clients.producer.internals.Sender.run(Sender.java:239)
>   at java.base/java.lang.Thread.run(Thread.java:834)
> Caused by: org.apache.kafka.common.errors.TimeoutException:
> Expiring 1 record(s) for save-request-0:604351 ms has passed since batch
> creation
>
> I have been fighting with him for the second week.
> Revised a bunch of fix recipes, but none of the recipes helped.
> My program sends messages about 60 kilobytes in size, but they do not
> reach the kafka server.
> The entire java application log is filled with exceptions of this kind.
>
>
> --
> С уважением, Влад Виниченко.
>