Flink kafka端到端Exactly-Once源码分析

FlinkKafkaProducer实现了TwoPhaseCommitSinkFunction,也就是两阶段提交。关于两阶段提交的原理,可以参见《An Overview of End-to-End Exactly-Once Processing in Apache Flink》,本文不再赘述两阶段提交的原理,但是会分析FlinkKafkaProducer源码中是如何实现两阶段提交的,并保证了在结合kafka的时候做到端到端的Exactly Once语义的。

TwoPhaseCommitSinkFunction分析

public abstract class TwoPhaseCommitSinkFunction<IN, TXN, CONTEXT>
      extends RichSinkFunction<IN>
      implements CheckpointedFunction, CheckpointListener

TwoPhaseCommitSinkFunction实现了CheckpointedFunctionCheckpointListener接口,首先就是在initializeState方法中开启事务,对于flink sink的两阶段提交,第一阶段就是执行CheckpointedFunction#snapshotState当所有task的checkpoint都完成之后,每个task会执行CheckpointedFunction#notifyCheckpointComplete也就是所谓的第二阶段

FlinkKafkaProducer第一阶段分析

pre-commit
@Override
public void snapshotState(FunctionSnapshotContext context) throws Exception {
   // this is like the pre-commit of a 2-phase-commit transaction
   // we are ready to commit and remember the transaction

   checkState(currentTransactionHolder != null, "bug: no transaction object when performing state snapshot");

   long checkpointId = context.getCheckpointId();
   LOG.debug("{} - checkpoint {} triggered, flushing transaction '{}'", name(), context.getCheckpointId(), currentTransactionHolder);

   preCommit(currentTransactionHolder.handle);
   pendingCommitTransactions.put(checkpointId, currentTransactionHolder);
   LOG.debug("{} - stored pending transactions {}", name(), pendingCommitTransactions);

   currentTransactionHolder = beginTransactionInternal();
   LOG.debug("{} - started new transaction '{}'", name(), currentTransactionHolder);

   state.clear();
   state.add(new State<>(
      this.currentTransactionHolder,
      new ArrayList<>(pendingCommitTransactions.values()),
      userContext));
}

这部分代码的核心在于

  1. 先执行preCommit方法,EXACTLY_ONCE模式下会调flush,立即将数据发送到指定的topic,这时如果消费这个topic,需要指定isolation.levelread_committed表示消费端应用不可以看到未提交的事物内的消息。

    @Override
    protected void preCommit(FlinkKafkaProducer.KafkaTransactionState transaction) throws FlinkKafkaException {
       switch (semantic) {
          case EXACTLY_ONCE:
          case AT_LEAST_ONCE:
             flush(transaction);
             break;
          case NONE:
             break;
          default:
             throw new UnsupportedOperationException("Not implemented semantic");
       }
       checkErroneous();
    }
    

    注意第一次调用的sendflush的事务都是在initializeState方法中开启事务

    transaction.producer.send(record, callback);
    
    transaction.producer.flush();
    
  2. pendingCommitTransactions保存了每个checkpoint对应的事务,并为下一次checkpoint创建新的producer事务,即currentTransactionHolder = beginTransactionInternal();下一次的sendflush都会在这个事务中。也就是说第一阶段每一个checkpoint都有自己的事务,并保存在pendingCommitTransactions中。

FlinkKafkaProducer第二阶段分析

commit

当所有checkpoint都完成后,会进入第二阶段的提交,

@Override
public final void notifyCheckpointComplete(long checkpointId) throws Exception {
   // the following scenarios are possible here
   //
   //  (1) there is exactly one transaction from the latest checkpoint that
   //      was triggered and completed. That should be the common case.
   //      Simply commit that transaction in that case.
   //
   //  (2) there are multiple pending transactions because one previous
   //      checkpoint was skipped. That is a rare case, but can happen
   //      for example when:
   //
   //        - the master cannot persist the metadata of the last
   //          checkpoint (temporary outage in the storage system) but
   //          could persist a successive checkpoint (the one notified here)
   //
   //        - other tasks could not persist their status during
   //          the previous checkpoint, but did not trigger a failure because they
   //          could hold onto their state and could successfully persist it in
   //          a successive checkpoint (the one notified here)
   //
   //      In both cases, the prior checkpoint never reach a committed state, but
   //      this checkpoint is always expected to subsume the prior one and cover all
   //      changes since the last successful one. As a consequence, we need to commit
   //      all pending transactions.
   //
   //  (3) Multiple transactions are pending, but the checkpoint complete notification
   //      relates not to the latest. That is possible, because notification messages
   //      can be delayed (in an extreme case till arrive after a succeeding checkpoint
   //      was triggered) and because there can be concurrent overlapping checkpoints
   //      (a new one is started before the previous fully finished).
   //
   // ==> There should never be a case where we have no pending transaction here
   //

   Iterator<Map.Entry<Long, TransactionHolder<TXN>>> pendingTransactionIterator = pendingCommitTransactions.entrySet().iterator();
   checkState(pendingTransactionIterator.hasNext(), "checkpoint completed, but no transaction pending");
   Throwable firstError = null;

   while (pendingTransactionIterator.hasNext()) {
      Map.Entry<Long, TransactionHolder<TXN>> entry = pendingTransactionIterator.next();
      Long pendingTransactionCheckpointId = entry.getKey();
      TransactionHolder<TXN> pendingTransaction = entry.getValue();
      if (pendingTransactionCheckpointId > checkpointId) {
         continue;
      }

      LOG.info("{} - checkpoint {} complete, committing transaction {} from checkpoint {}",
         name(), checkpointId, pendingTransaction, pendingTransactionCheckpointId);

      logWarningIfTimeoutAlmostReached(pendingTransaction);
      try {
         commit(pendingTransaction.handle);
      } catch (Throwable t) {
         if (firstError == null) {
            firstError = t;
         }
      }

      LOG.debug("{} - committed checkpoint transaction {}", name(), pendingTransaction);

      pendingTransactionIterator.remove();
   }

   if (firstError != null) {
      throw new FlinkRuntimeException("Committing one of transactions failed, logging first encountered failure",
         firstError);
   }
}

这一阶段会将pendingCommitTransactions中的事务全部提交

@Override
protected void commit(FlinkKafkaProducer.KafkaTransactionState transaction) {
   if (transaction.isTransactional()) {
      try {
         transaction.producer.commitTransaction();
      } finally {
         recycleTransactionalProducer(transaction.producer);
      }
   }
}

这时消费端就能看到read_committed的数据了,至此整个producer的流程全部结束。

Exactly-Once分析

当输入源和输出都是kafka的时候,flink之所以能做到端到端的Exactly-Once语义,主要是因为第一阶段FlinkKafkaConsumer会将消费的offset信息通过checkpoint保存,所有checkpoint都成功之后,第二阶段FlinkKafkaProducer才会提交事务,结束producer的流程。这个过程中很大程度依赖了kafka producer事务的机制,可以参考Kafka事务

总结

本文主要分析了flink结合kafka是如何实现Exactly-Once语义的。

注:本文基于flink 1.9.0和kafka 2.3

参考

Flink kafka source源码解析
Flink kafka sink源码解析

最后编辑于
©著作权归作者所有,转载或内容合作请联系作者
  • 序言:七十年代末,一起剥皮案震惊了整个滨河市,随后出现的几起案子,更是在滨河造成了极大的恐慌,老刑警刘岩,带你破解...
    沈念sama阅读 160,227评论 4 364
  • 序言:滨河连续发生了三起死亡事件,死亡现场离奇诡异,居然都是意外死亡,警方通过查阅死者的电脑和手机,发现死者居然都...
    沈念sama阅读 67,755评论 1 298
  • 文/潘晓璐 我一进店门,熙熙楼的掌柜王于贵愁眉苦脸地迎上来,“玉大人,你说我怎么就摊上这事。” “怎么了?”我有些...
    开封第一讲书人阅读 109,899评论 0 244
  • 文/不坏的土叔 我叫张陵,是天一观的道长。 经常有香客问我,道长,这世上最难降的妖魔是什么? 我笑而不...
    开封第一讲书人阅读 44,257评论 0 213
  • 正文 为了忘掉前任,我火速办了婚礼,结果婚礼上,老公的妹妹穿的比我还像新娘。我一直安慰自己,他们只是感情好,可当我...
    茶点故事阅读 52,617评论 3 288
  • 文/花漫 我一把揭开白布。 她就那样静静地躺着,像睡着了一般。 火红的嫁衣衬着肌肤如雪。 梳的纹丝不乱的头发上,一...
    开封第一讲书人阅读 40,757评论 1 221
  • 那天,我揣着相机与录音,去河边找鬼。 笑死,一个胖子当着我的面吹牛,可吹牛的内容都是我干的。 我是一名探鬼主播,决...
    沈念sama阅读 31,982评论 2 315
  • 文/苍兰香墨 我猛地睁开眼,长吁一口气:“原来是场噩梦啊……” “哼!你这毒妇竟也来了?” 一声冷哼从身侧响起,我...
    开封第一讲书人阅读 30,715评论 0 204
  • 序言:老挝万荣一对情侣失踪,失踪者是张志新(化名)和其女友刘颖,没想到半个月后,有当地人在树林里发现了一具尸体,经...
    沈念sama阅读 34,454评论 1 246
  • 正文 独居荒郊野岭守林人离奇死亡,尸身上长有42处带血的脓包…… 初始之章·张勋 以下内容为张勋视角 年9月15日...
    茶点故事阅读 30,666评论 2 249
  • 正文 我和宋清朗相恋三年,在试婚纱的时候发现自己被绿了。 大学时的朋友给我发了我未婚夫和他白月光在一起吃饭的照片。...
    茶点故事阅读 32,148评论 1 261
  • 序言:一个原本活蹦乱跳的男人离奇死亡,死状恐怖,灵堂内的尸体忽然破棺而出,到底是诈尸还是另有隐情,我是刑警宁泽,带...
    沈念sama阅读 28,512评论 3 258
  • 正文 年R本政府宣布,位于F岛的核电站,受9级特大地震影响,放射性物质发生泄漏。R本人自食恶果不足惜,却给世界环境...
    茶点故事阅读 33,156评论 3 238
  • 文/蒙蒙 一、第九天 我趴在偏房一处隐蔽的房顶上张望。 院中可真热闹,春花似锦、人声如沸。这庄子的主人今日做“春日...
    开封第一讲书人阅读 26,112评论 0 8
  • 文/苍兰香墨 我抬头看了看天上的太阳。三九已至,却和暖如春,着一层夹袄步出监牢的瞬间,已是汗流浃背。 一阵脚步声响...
    开封第一讲书人阅读 26,896评论 0 198
  • 我被黑心中介骗来泰国打工, 没想到刚下飞机就差点儿被人妖公主榨干…… 1. 我叫王不留,地道东北人。 一个月前我还...
    沈念sama阅读 35,809评论 2 279
  • 正文 我出身青楼,却偏偏与公主长得像,于是被迫代替她去往敌国和亲。 传闻我的和亲对象是个残疾皇子,可洞房花烛夜当晚...
    茶点故事阅读 35,691评论 2 272

推荐阅读更多精彩内容