You are viewing a plain text version of this content. The canonical link for it is here.
Posted to jira@kafka.apache.org by "lqjacklee (Jira)" <ji...@apache.org> on 2022/05/25 17:53:00 UTC

[jira] [Commented] (KAFKA-13884) KRaft Obsever are not required to flush on every append

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

lqjacklee commented on KAFKA-13884:
-----------------------------------

[~jagsancio] I plan add observer.refresh.time.ms in the org.apache.kafka.raft.RaftConfig. Once the observer receive FetchResponse, I will check the condition that System.currentTimeMillis()-lastFetchRefreshTimeMs > observer.refresh.time.ms. I will flush the log and update the HWM. what’s do you think? 

> KRaft Obsever are not required to flush on every append
> -------------------------------------------------------
>
>                 Key: KAFKA-13884
>                 URL: https://issues.apache.org/jira/browse/KAFKA-13884
>             Project: Kafka
>          Issue Type: Sub-task
>            Reporter: Jose Armando Garcia Sancio
>            Priority: Major
>
> The current implementation of the KRaft Client flushes to disk when observers append to the log. This is not required since observer don't participate in leader election and the advancement of the high-watermark.



--
This message was sent by Atlassian Jira
(v8.20.7#820007)