group.instance.id
组静态成员,避免瞬时的消费者不可用导致的rebalance
group.instance.id
组静态成员,避免瞬时的消费者不可用导致的rebalance
ReplicaManager主要负责日志的写入以及副本的同步,如果ack配置的不是0,则需要等待副本写入满足acks才会回复响应。同时ReplicaManager会定时检查ISR是否已经不再同步,主要是看当前副本的LEO与Leader的LEO是否相同,或者上次lag的时间是否超过replica.lag.time.max.ms,默认30s
分区读取状态
分区读取状态一般是Leader的状态吧
可见,副本读取状态有截断中和获取中两个:当副本执行截断操作时,副本状态被设置成 Truncating;当副本被读取时,副本状态被设置成 Fetching。
就是当前副本的状态,是否可以去Fetch,如果当前在截断中,就不能Fetch,而如果被delay了同理
def isReplicaInSync: Boolean = lag.isDefined && lag.get <= 0
副本处于ISR中居然是lag为0
highWatermark
各副本已经同步的消息offset, HW leader节点从所有的副本中获取LEO,取最小的LEO做HW,HW为所有已经成功写入全部副本的消息的最新位置。Follower的HW则是他的LEO和leader的HW的较小值
lastStableOffset 是最新的 LSO 值,属于 Kafka 事务的概念。
LSO,最早的一个未提交事务前的位点,也就是read commit能读取的位置
副本对外提供读取服务
这是社区为了规避因多线程访问产生锁争用导致线程阻塞,从而引发请求超时问题而做的努力
当多线程同时执行该方法进行检查的时候,拿到锁的线程complete失败,而没拿到锁的线程直接跳过,那么如果没有其他线程再去处理的话,就永远也不会complete。
如果第一个线程成功将retry设置为false,那么第二个线程就会进行重试,而如果本身retry就是true,那么说明被其他线程先一步设置了,该线程不重试。但是如果多个线程顺序执行,都完成不了,那不是一样?
bucket.flush(reinsert)
相当于重新添加进时间轮,但是如果已经到了时间,那么就会执行。而且由于时间轮向后滚动,如果是最下面一级的bucket则所有元素都会过期,而上一级的bucket则会往下一级插入.
首先是以bucket为单位写入DelayQueue,bucket通过分层,使得每一层只有20个bucket,那么n层就只有n*20个bucket,大大减少了DelayQueue元素的数量,减小时间复杂度。
delayQueue
为什么这里有一个存储所有TimerTaskList的DelayQueue?那我为什么不直接把所有任务往队列里面塞?这样不还是O(logn)时间复杂度吗插入
选择存活副本列表的第一个副本作为 Leader;选择存活副本列表作为 ISR
NewPartition状态的分区,进行初始化(因为是初始化,所以数据都为空),会将存活副本设置为ISR,而将ISR第一个设置为Leader
基本上就是,找出 AR 列表(或给定副本列表)中首个处于存活状态,且在 ISR 列表的副本,将其作为新 Leader。
Leader选举
即副本所在的 Broker 依然在运行中
心跳机制来确定broker的状态
AR表示分区的副本,而ISR表示与Leader同步的副本
这是分区的副本列表。该列表有个专属的名称,叫 Assigned Replicas,简称 AR
AR
实际上消息队列都是以分区为单位组织的。而一个topic拥有多个分区,客户端可以根据一定的规则(Partitioner)往这多个分区中写入数据,而消费者则通过一定规则或者随机分配到部分partition,从partition中顺序进行消费
PartitionStateMachine定义的是分区是否有Leader
PartitionLeaderElectionStrategy 接口及其实现对象:定义 4 类分区 Leader 选举策略。你可以认为它们是发生 Leader 选举的 4 种场景。
什么时候会发生分区Leader选举?
代码会给所有符合状态转换的副本所在的 Broker,发送 StopReplicaRequest 请求,显式地告诉这些 Broker 停掉其上的对应副本。Kafka 的副本管理器组件(ReplicaManager)负责处理这个逻辑。后面我们会用两节课的时间专门讨论 ReplicaManager 的实现,这里你只需要了解,StopReplica 请求被发送出去之后,这些 Broker 上对应的副本就停止工作了。
通过重试兜底保证最终一致性?同时如果主从切换的话,会进行检查然后重新进行状态同步
不需要,Controller发送请求后会异步的等待broker心跳中包含的响应。同时由于MQ本身的设计能够进行容错,即旧的状态如果不对,那么会进行重试,或者刷新缓存元数据
源码会获取对应分区的详细数据,然后向该副本对象所在的 Broker 发送 LeaderAndIsrRequest 请求,令其同步获知,并保存该分区数据。
因为最前面判定了validReplicas,所以这些状态的变更都是允许的
尝试从元数据缓存中,
为什么要以元数据缓存为准?
doHandleStateChanges 方法
副本状态变更流程
它会将 replicas 按照 Broker ID 进行分组。
按brokerId分组进行副本状态变更
(validBytes - lastIndexEntry > indexIntervalBytes)
recover过程中会重置索引,然后遍历每个batch来添加索引项,这样就能避免掉原本写入消息时,一次性写入的多batch的消息最多只写入一次索引导致查询效率低的问题
recover 方法
kafka在shutdown的时候会将segment刷盘并维护checkpoint和.kafka_cleanshutdown文件,每个partition一份.重启的时候会进行判定
因为目前 Broker 端日志段新增倒计时是全局设置,这就是说,在未来的某个时刻可能同时创建多个日志段对象,这将极大地增加物理磁盘 I/O 压力。有了 rollJitterMs 值的干扰,每个新增日志段在创建时会彼此岔开一小段时间,这样可以缓解物理磁盘的 I/O 负载瓶颈。
配置topic的segment.jitter.ms或者segment.ms让segment根据时间自动滚动时错峰,避免io压力过大
即使segment的数据量不大,超过固定时间(默认一周)没写入数据,也会滚动segment,那如果很多segment都没写入的话,那么就会同时创建segment导致大量的io占用 rollJitterMs则是一个随机的扰动值,来源于{@link LogConfig#randomSegmentJitter()}, 通过这个值可以将segment滚动的时间错开,缓解物理磁盘的 I/O 负载瓶颈
Follower 副本拉取消息后写入副本;
不需要顾及acks,直接写入副本即可
但是为什么 AbstractFetcherThread 线程总要不断尝试去做截断呢?这是因为,分区的 Leader 可能会随时发生变化。每当有新 Leader 产生时,Follower 副本就必须主动执行截断操作,将自己的本地日志裁剪成与 Leader 一模一样的消息序列,甚至,Leader 副本本身也需要执行截断操作,将 LEO 调整到分区高水位处。
当leader变更时,follower需要truncate自己的日志来保证与leader一致,而leader切换的时候,自身也需要truncate到HW来保持数据的一致性,但是这样会丢消息,当然如果没有到HW,那么需要所有节点同步的消息应该收不到回复
lastStableOffset
LSO,和事务相关,当前如果有事务的话,没有提交的事务的消息对用户是不可见的,因此LSO在这个事务消息的前面来进行标记
Leader如何知道当前的同步进度?
partition的高水位线表示当前已同步的offset,这些消息是安全的,可以被consumer消费,因此通过这个可以看到消息的同步进度 参考
如果Leader挂了,follower要达到什么标准才能成为leader?是否可能丢失数据?
副本同步的时候,谁主动进行同步?
How Tesla is using Kubernetes and Kafka to handle trillions of events per day
Overview of Tesla's Data Infrastructure Challenges:
Kubernetes for Orchestration:
Kafka for Real-Time Event Streaming:
Data Processing Pipelines:
Key Technical Advantages:
Simplified Management:
Future Goals and Improvements:
Partition Leader Balancing
balance the load on leader preferred replica - first replica of each partition preferred replica is evenly distributed among brokers tries to make the preferred replica as the leader and hence balancing the load
Replication
followers that lag behind replica lag time max ms is removed from the ISR
Kafka
follower failure is handled by removing the lagging or failed followers from the ISR and considering only the rest and moves the high watermark
Protocol
a log is committed when all replicas are in sync - ISR - then we move watermark
Data Plane
only data upto high watermark is visible to the consumers
Replication
leaders&followers leader commits log with an epoch(indicates generation of lifetime of a log) follower fetch with offset no to sync with leader leader reponds with new record logs with epoch in the next fetch request, leader moves high watermark based on offset in request (n-1) in that response it passes the high watermark to the follower
course
how data is received client -> socket -> n/w thread(lightweight) -> req queue -> i/o thread(crc check & append to commit log[.index and .log file]) -> resp queue -> n/w-> socket
purgatory map -> used for req until data is replicated
how data is fetched client -> socket -> n/w -> req queue -> i/o thread (fetch ranges are calcualted with .index) -> res queue -> n/w -> socket
purgatory map -> waits until is arrived based on consumer config
also follows zero copy - meaning data fetched from file directly to n/w thread - mostly page cached
if not cached -> may need to use tiered storage
Inside the Apache Kafka Broker
consumer properties => same as producer, time and batch size.
Kafka Broker
producer key properties => linger time -> linger.ms batch size -> batch.size
these determine the throughput and latency of kafkaproducers
Today is 9th Feb. The oldest segment – segment 100 – still can’t be deleted by the 7-day topic retention policy, because the most recent message in that segment is only 5 days old. The result is that they can see messages dating back to 28th January on this topic, even though the 28th Jan is now 12 days ago. In a couple of days, all the messages in segment 100 will be old enough to exceed the retention threshold so that segment file will be deleted.
retention.ms set to 7 days doesn't guarantee that you will only see topic messages from the last 7 days. Think of it as a threshold that the Kafka broker can use to decide when messages are eligible for being automatically deleted.
Wonderful conversation between Sheila Heti, her brother, and three of their friends, about the Annie Hall 'I need the eggs' joke that ends the film.
The Bitnami Apache Kafka docker image disables the PLAINTEXT listener for security reasons. You can enable the PLAINTEXT listener by adding the next environment variable, but remember that this configuration is not recommended for production.
production note
RabbitMQ,ZeroMQ,Kafka 是一个层级的东西吗?相互之间有哪些优缺点?
没有用户态到核心态的拷贝
构建一个高吞吐量的 metrics 系统的思考过程
它采用pull机制,而 不是一般MQ的push模型
rabbitmq是push模型,kafka是pull模型
You don’t have to download them manually, as a docker-compose.yml will do that for you. Here’s the code, so you can copy it to your machine:
Sample docker-compose.yml file to download both: Kafka and Zookeeper containers
Kafka version 2.8.0 introduced early access to a Kafka version without Zookeeper, but it’s not ready yet for production environments.
In the future, Zookeeper might be no longer needed to operate Kafka
Kafka consumer — A program you write to get data out of Kafka. Sometimes a consumer is also a producer, as it puts data elsewhere in Kafka.
Simple Kafka consumer terminology
Kafka producer — An application (a piece of code) you write to get data to Kafka.
Simple producer terminology
Kafka topic — A category to which records are published. Imagine you had a large news site — each news category could be a single Kafka topic.
Simple Kafka topic terminology
Kafka broker — A single Kafka Cluster is made of Brokers. They handle producers and consumers and keeps data replicated in the cluster.
Simple Kafka broker terminology
Kafka — Basically an event streaming platform. It enables users to collect, store, and process data to build real-time event-driven applications. It’s written in Java and Scala, but you don’t have to know these to work with Kafka. There’s also a Python API.
Simple Kafka terminology
User topics must be created and manually managed ahead of time
Javadoc says: "should be created".
The reason is: Auto-creation of topics may be disabled in your Kafka cluster. Auto-creation automatically applies the default topic settings such as the replicaton factor. These default settings might not be what you want for certain output topics (e.g., auto.create.topics.enable=true in the Kafka broker configuration).
In the Penal Settlement
בעברית: במושבת העונשין
Macksey is also responsible for one of his first short films. “When I was at Hopkins, there was no film program. We talked to Dick [about making a short film] and he said ‘let’s do it,’ and we ended up doing a movie in which he has a small part.”
The short black and white film of just a few minutes was called Fratricide and is based on the Franz Kafka story A Fratricide.
 <small>Caleb Deschanel on the set of Fratricide. This may likely have been his first DP job circa ’66 while a student at Johns Hopkins. Photo courtesy of classmate Henry James Korn.</small>
<small>Caleb Deschanel on the set of Fratricide. This may likely have been his first DP job circa ’66 while a student at Johns Hopkins. Photo courtesy of classmate Henry James Korn.</small>
This minimal, yet poignant presence is reflected in the brick work—Kafka’s novel showcasing how a small idea can have a monumental presence.
love it!
Now he stood there naked.
Why naked? How do you read this little ritual of disrobing? What might it have to do with the comedy that happens in the preceding paragraph?
his women
Third or fourth mention of the Commandant's 'women.' Connection to 'Honour your superiors'? Objectification of marginalized groups.
I usually kneel down at this point and observe the phenomenon.
The fetishistic obsession with inscription is particularly disturbing here.
Guilt is always beyond a doubt.
Unlikely.
“It would be useless to give him that information. He experiences it on his own body.
But hasn't the Condemned Man already experienced this subjection and degradation in his body? (like a vandalized house) The inscription of it on his body simply embodies what has already been true.
“That’s cotton wool?” asked the Traveler and bent down. “Yes, it is,” said the Officer smiling, “feel it for yourself.”
Kafka keeps bringing our attention to the cotton, perhaps to ensure we recognize the historical implications?
harrow
Common term used in farming/planting.
epaulettes
According to Google, "an ornamental shoulder piece on an item of clothing, typically on the coat or jacket of a military uniform"
the administration of the colony was so self-contained that even if his successor had a thousand new plans in mind, he would not be able to alter anything of the old plan, at least not for several years.
Horrifying.
vacant-looking man with a broad mouth and dilapidated hair and face
The descriptors "Vacant-looking" and "dilapidated" summon up imagery of haunted houses and manors left in ruin rather than people. These terms are primarily used to describe things, not people.
Why then is our "Condemned" an empty house? What has pushed him from subject to object in this way?
Officer to the Traveler,
Officer, Traveler, Condemned. Everyone is defined solely by the roles that they inhabit.
Then the Traveler heard a cry of rage from the Officer.
How does affect work in this tale? What kinds of feelings are evoked in whom by what kinds of stimuli? What do these eruptions of feeling tell us about the unspoken value system that undergirds this society?
That gave rise to certain technical difficulties with fastening the needles securely, but after several attempts we were successful. We didn’t spare any efforts. And now, as the inscription is made on the body, everyone can see through the glass. Don’t you want to come closer and see the needles for yourself.”
Why glass? Given that the Apparatus is a mere tool, an agent of "justice," why such pains to make its workings visible? Why talk about it so much?
The Traveler wanted to raise various questions, but after looking at the Condemned Man he merely asked, “Does he know his sentence?” “No,” said the Officer. He wished to get on with his explanation right away, but the Traveler interrupted him: “He doesn’t know his own sentence?” “No,” said the Officer once more. He then paused for a moment, as if he was asking the Traveler for a more detailed reason for his question, and said, “It would be useless to give him that information. He experiences it on his own body.”
How you you read this crucial moment? Who knows what in this story, and how does Kafka exploit the lack of symmetry between Commandant, Officer, Traveler, Condemned, and so on?
“He was indeed,” said the Officer, nodding his head with a fixed and thoughtful expression. Then he looked at his hands, examining them. They didn’t seem to him clean enough to handle the diagrams. So he went to the bucket and washed them again. Then he pulled out a small leather folder and said, “Our sentence does not sound severe. The law which a condemned man has violated is inscribed on his body with the harrow. This Condemned Man, for example,” and the Officer pointed to the man, “will have inscribed on his body, ‘Honour your superiors.’”
Alas, the double entendre of "sentence" as a grammatical and legal entity at once is not active in German, but the slippage certainly fits here!
“However,” the Officer said, interrupting himself, “I’m chattering, and his apparatus stands here in front of us. As you see, it consists of three parts. With the passage of time certain popular names have been developed for each of these parts. The one underneath is called the bed, the upper one is called the inscriber, and here in the middle, this moving part is called the harrow.” “The harrow?” the Traveler asked. He had not been listening with full attention. The sun was excessively strong, trapped in the shadowless valley, and one could hardly collect one’s thoughts. So the Officer appeared to him all the more admirable in his tight tunic weighed down with epaulettes and festooned with braid, ready to go on parade, as he explained the matter so eagerly and, while he was talking, adjusted screws here and there with a screwdriver.
What's the effect of Kafka's use of abstraction here? Those who know his other works are perhaps used to this stylistic feature, but why the abstract titles/names, from Commandant to Traveler to apparatus?
Of course, interest in the execution was not very high, not even in the penal colony itself.
What's the tone of this story? Why does it matter that no one is interested in the execution, including the condemned?
The Log: What every software engineer should know about real-time data's unifying abstraction
SubscribePattern allows you to use a regex to specify topics of interest
This can remove the need to reload the kafka writers in order to take consume messages.
regex - "topic-ua-*"
The cache for consumers has a default maximum size of 64. If you expect to be handling more than (64 * number of executors) Kafka partitions, you can change this setting via spark.streaming.kafka.consumer.cache.maxCapacity.
You might need this for keeping track of all partitions consumed.
In distributed mode, you start many worker processes using the same group.id and they automatically coordinate to schedule execution of connectors and tasks across all available workers. I
Distributed workers.
group.id = "SHOUDL BE THE SAME FOR ALL WORKERS"
Connectors and tasks are logical units of work and must be scheduled to execute in a process. Kafka Connect calls these processes workers and has two types of workers: standalone and distributed.
Workers = JVM processes
up vote 7 down vote accepted When you are starting your kafka broker you can define set of properties in conf/server.properties file. This file is just key value property file. One of the property is auto.create.topics.enable if it set tot true(by default) kafka will create topic automatically when you send message to non existing topic. All config options you can find here Imho Simple rule for creating topics is the following: number of replicas must be not less than number of nodes that you have. Number of topics must be the multiplier of number of node in your cluster for example: You have 9 node cluster your topic must have 9 partitions and 9 replicas or 18 partitions and 9 replicas or 36 partitions and 9 replicas and so on
Number of replicas = #replicas Number of nodes = #nodes Number of topics = #topic
k x (#topics) = #nodes
ab -t 15 -k -T "application/vnd.kafka.binary.v1+json" -p postfile http://localhost:8082/topics/test
ab benchmark
in sync replicas (ISRs) should be exactly equal to the total number of replicas.
ISRs are a very imp metric
Kafka metrics can be broken down into three categories:Kafka server (broker) metricsProducer metricsConsumer metrics
3 Metrics:
"isr" is the set of "in-sync" replicas.
ISR are pretty import as when nodes go down you will see replicas created later.
We run Kafka on the old and trusty m1.xlarge
aws kafka m1.xlarge
You measure the throughout that you can achieve on a single partition for production (call it p) and consumption (call it c). Let’s say your target throughput is t.
t = throughput (QPS) p = single partition for production c = consumption
Messages are immediately written to the filesystem when they are received. Messages are not deleted when they are read but retained with some configurable SLA (say a few days or a week)
ZooKeeper snapshots can be one such a source of concurrent writes, and ideally should be written on a disk group separate from the transaction log.
zookeeper maintains concurrency in its own way.
If you do end up sharing the ensemble, you might want to use the chroot feature. With chroot, you give each application its own namespace.
jail zookeeper instance from the other apps
Very useful kafka command-line tools to keep track of what's happening in your kafka cluster.
Designing a High Level Consumer
By far the most important thing you need to know to make SECOR operate with Kafkaf
the High Level Consumer is provided to abstract most of the details of consuming events from Kafka.
In merced, we used the low-level simple consumer and wrote our own work dispatcher to get precise control.
difference between merced and secor
A better alternative is at least once message delivery. For at least once delivery, the consumer reads data from a partition, processes the message, and then commits the offset of the message it has processed. In this case, the consumer could crash between processing the message and committing the offset and when the consumer restarts it will process the message again. This leads to duplicate messages in downstream systems but no data loss.
This is what SECOR does.
no data loss will occur as long as producers and consumers handle this possibility and retry appropriately.
Retries should be built into the consumer and producer code. If leader for the partition fails, you will see a LeaderNotAvailable Exception.
By electing a new leader as soon as possible messages may be dropped but we will minimized downtime as any new machine can be leader.
two scenarios to get the leader back: 1.) Wait to bring the master back online. 2.) Or elect the first node that comes back up. But in this scenario if that replica partition was a bit behind the master then the time from when this replica went down to when the master went down. All that data is Lost.
SO there is a trade off between availability and consistency. (Durability)
keep in mind that these guarantees hold as long as you are producing to one partition and consuming from one partition.
This is very important a 1-to-1 mapping between writer and reader with partition. If you have more producers per partition or more consumers per partition your consistency is going to go haywire
On every received heartbeat, the coordinator starts (or resets) a timer. If no heartbeat is received when the timer expires, the coordinator marks the member dead and signals the rest of the group that they should rejoin so that partitions can be reassigned. The duration of the timer is known as the session timeout and is configured on the client with the setting session.timeout.ms.
Time to live for the consumers. If the heartbeat doesn't reach the co-ordindator in this duration then the co-ordinator redistributes the partitions to the remaining consumers in the consumer group.
The high watermark is the offset of the last message that was successfully copied to all of the log’s replicas.
High Watermark: messages copied over to log replicas
Kafka new Client which uses a different protocol for consumption in a distributed environment.
Kafka scales topic consumption by distributing partitions among a consumer group, which is a set of consumers sharing a common group identifier.
Topic consumption is distributed among a list of consumer group.
Kafka consumer offset management protocol to keep track of what’s been uploaded to S3
consumers keep track of what's written and where it left off by looking at kafka consumer offsets rather than checking S3 since S3 is an eventually consistent system.
Data lost or corrupted at this stage isn’t recoverable so the greatest design objective for Secor is data integrity.
data loss in S3 is being mitigated.
An index can potentially store a large amount of data that can exceed the hardware limits of a single node. For example, a single index of a billion documents taking up 1TB of disk space may not fit on the disk of a single node or may be too slow to serve search requests from a single node alone.
Indexes may overflow the disk space. Hence you want to get the most out of your instances by indexing the nodes.
incidents are an unavoidable reality of working with distributed systems, no matter how reliable. A prompt alerting solution should be an integral part of the design,
see how it can hook into the current logging mechanism
Consumers in this group are designed to be dead-simple, performant, and highly resilient. Since the data copied verbatim, no code upgrades are required to support new message types.
exactly what we want
More events may arrive late for various reasons, we need to handle late-arrived events consistently.
May not be needed for our use case.
With Flume & FlumeNG, and a File channel, if you loose a broker node you will lose access to those events until you recover that disk.
In flume you loose events if the disk is down. This is very bad for our usecase.
The Kafka cluster retains all published records—whether or not they have been consumed—using a configurable retention period. For example, if the retention policy is set to two days, then for the two days after a record is published, it is available for consumption, after which it will be discarded to free up space. Kafka's performance is effectively constant with respect to data size so storing data for a long time is not a problem.
irrespective of the fact that the consumer has consumed the message that message is kept in kafka for the entire retention policy duration.
You can have two or more consumer groups: 1 -> real time 2 -> back up consumer group
Kafka for Stream Processing
Could be something we can consider for directing data from a raw log to a tenant based topic.
replication factor N, we will tolerate up to N-1 server failures without losing any records
Replication Factor means number of nodes/brokers which could go down before we start losing data.
So if you have a replication factor of 6 for a 11 node cluster, then you will be fault tolerant till 5 nodes go down. After that point you are going to loose data for a particular partition.
Messages sent by a producer to a particular topic partition will be appended in the order they are sent. That is, if a record M1 is sent by the same producer as a record M2, and M1 is sent first, then M1 will have a lower offset than M2 and appear earlier in the log.
ordering is guaranteed.
Consumers label themselves with a consumer group name, and each record published to a topic is delivered to one consumer instance within each subscribing consumer group. Consumer instances can be in separate processes or on separate machines.
kafka takes care of the consumer groups. Just create one Consumer Group for each topic.
The partitions of the log are distributed over the servers in the Kafka cluster with each server handling data and requests for a share of the partitions.
partitions of logs are per TOPIC basis
The first limitation is that each partition is physically represented as a directory of one or more segment files. So you will have at least one directory and several files per partition. Depending on your operating system and filesystem this will eventually become painful. However this is a per-node limit and is easily avoided by just adding more total nodes in the cluster.
total number of topics supported depends on the total number of partitions per topic.
partition = directory of 1 or more segment files This is a per node limit
the number of partitions -- there's no real "formula" other than this: you can have no more parallelism than you have partitions.
This is an important thing to keep in mind. If we need massive parallelism we need to have more partitions.
The offset the ordering of messages as an immutable sequence. Kafka maintains this message ordering for you.
Kafka maintains the ordering for you...
replication-factor 3
If n-1=2 nodes go down you will start loosing data. So that means if both the nodes go down you will loose data.
For a topic with replication factor N, we will tolerate up to N-1 server failures without losing any records committed to the log.
for Eg for a given topic there are 11 brokers/servers and for each topic the replication factor is 6. That means the topic will start loosing data if more than 5 brokers go down.
The way consumption is implemented in Kafka is by dividing up the partitions in the log over the consumer instances so that each instance is the exclusive consumer of a "fair share" of partitions at any point in time. This process of maintaining membership in the group is handled by the Kafka protocol dynamically. If new instances join the group they will take over some partitions from other members of the group; if an instance dies, its partitions will be distributed to the remaining instances.
The coolest feature: this way all you need to do is add new consumers in a consumer group to auto scale per topic
Consumers label themselves with a consumer group name
maintain separate consumer group per tenant basis. Helps to scale out when we have more load per tenant.
The producer is responsible for choosing which record to assign to which partition within the topic.
Producer can publish to a specific topics
individual partition must fit on the servers that host it
Each Partition is bounded by the server that hosts that partition.
the only metadata retained on a per-consumer basis is the offset or position of that consumer in the log. This offset is controlled by the consumer: normally a consumer will advance its offset linearly as it reads records, but, in fact, since the position is controlled by the consumer it can consume records in any order it likes.
partition offset maintained by kafka. Offset number is maintained so that if the consumer goes down nothing breaks.
the retention policy is set to two days, then for the two days after a record is published,
Might have to tweek this based on the persistence level we want to keep.