pom.xml
<?xml version="1.0" encoding="UTF-8"?>
<project xmlns="http://maven.apache.org/POM/4.0.0"
xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
<modelVersion>4.0.0</modelVersion>
<groupId>com.mrathena.middle.ware</groupId>
<artifactId>kafka.base</artifactId>
<version>1.0.0</version>
<dependencies>
<!-- Toolkit -->
<dependency>
<groupId>com.mrathena</groupId>
<artifactId>toolkit</artifactId>
<version>1.1.1</version>
</dependency>
<!-- Lombok -->
<dependency>
<groupId>org.projectlombok</groupId>
<artifactId>lombok</artifactId>
<version>1.18.12</version>
</dependency>
<!-- Junit -->
<dependency>
<groupId>junit</groupId>
<artifactId>junit</artifactId>
<version>4.13</version>
<scope>test</scope>
</dependency>
<!-- Kafka -->
<dependency>
<groupId>org.apache.kafka</groupId>
<artifactId>kafka-clients</artifactId>
<version>2.4.1</version>
</dependency>
</dependencies>
<build>
<plugins>
<plugin>
<groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-compiler-plugin</artifactId>
<version>3.8.1</version>
<configuration>
<source>1.8</source>
<target>1.8</target>
<encoding>UTF-8</encoding>
</configuration>
</plugin>
</plugins>
</build>
</project>
消息体
package com.mrathena.kafka;
import lombok.*;
import java.io.Serializable;
@Getter
@Setter
@ToString
@NoArgsConstructor
@AllArgsConstructor
public class Order implements Serializable {
private static final long serialVersionUID = 1L;
private Long id;
private String mobile;
private Long amount;
private String username;
}
生产者
package com.mrathena.kafka;
import com.alibaba.fastjson.JSON;
import org.apache.kafka.clients.producer.*;
import org.apache.kafka.common.serialization.StringSerializer;
import java.util.Properties;
import java.util.concurrent.CountDownLatch;
public class ProducerTest {
/**
* 3-broker, 2-partition, 3-replica
*/
private final static String TOPIC = "test-3-2-3";
public static void main(String[] args) throws Throwable {
Properties properties = new Properties();
properties.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, "192.168.2.131:9092,192.168.2.132:9092,192.168.2.133:9092");
// 发出消息持久化机制参数
// (1)acks=0: 表示producer不需要等待任何broker确认收到消息的回复,就可以继续发送下一条消息。性能最高,但是最容易丢消息。
// (2)acks=1: 至少要等待leader已经成功将数据写入本地log,但是不需要等待所有follower是否成功写入。就可以继续发送下一条消息。
// 这种情况下,如果follower没有成功备份数据,而此时leader又挂掉,则消息会丢失。
// (3)acks=-1或all: 需要等待 min.insync.replicas (默认为1,推荐配置大于等于2) 这个参数配置的副本个数都成功写入日志,
// 这种策略会保证只要有一个备份存活就不会丢失数据。这是最强的数据保证。一般除非是金融级别,或跟钱打交道的场景才会使用这种配置。
// 如果 min.insync.replicas=1, 则acks=all和acks=1的效果一样
properties.put(ProducerConfig.ACKS_CONFIG, "1");
// 发送失败会重试,默认重试间隔100ms,重试能保证消息发送的可靠性,但是也可能造成消息重复发送,比如网络抖动,所以需要在接收者那边做好消息接收的幂等性处理
properties.put(ProducerConfig.RETRIES_CONFIG, 3);
// 每次重试之间的间隔
properties.put(ProducerConfig.RETRY_BACKOFF_MS_CONFIG, 300);
// 设置发送消息的本地缓冲区,如果设置了该缓冲区,消息会先发送到本地缓冲区,可以提高消息发送性能,默认值是33554432,即32MB
properties.put(ProducerConfig.BUFFER_MEMORY_CONFIG, 33554432);
// 本地线程会从本地缓冲区取数据,批量发送到broker,设置批量发送消息的大小,默认值是16384,即16kb,就是说一个batch满了16kb就发送出去
properties.put(ProducerConfig.BATCH_SIZE_CONFIG, 16384);
// 默认值是0,意思就是消息必须立即被发送,但这样会影响性能
// 一般设置10毫秒左右,就是说这个消息发送完后会进入本地的一个batch,如果10毫秒内,这个batch满了16kb就会随batch一起被发送出去
// 如果10毫秒内,batch没满,那么也必须把消息发送出去,不能让消息的发送延迟时间太长
properties.put(ProducerConfig.LINGER_MS_CONFIG, 10);
// 把发送的key从字符串序列化为字节数组
properties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, StringSerializer.class.getName());
// 把发送消息value从字符串序列化为字节数组
properties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, StringSerializer.class.getName());
Producer<String, String> producer = new KafkaProducer<>(properties);
int times = 9;
final CountDownLatch countDownLatch = new CountDownLatch(times);
for (long i = 1; i <= times; i++) {
Order order = new Order(i, "1823408981" + i, 123L * i, "mrathena" + i);
// 指定发送分区
// ProducerRecord<String, String> producerRecord = new ProducerRecord<>(TOPIC_NAME, 0, order.getId().toString(), JSON.toJSONString(order));
// ProducerRecord<String, String> producerRecord = new ProducerRecord<>(TOPIC_NAME, 1, order.getId().toString(), JSON.toJSONString(order));
// 未指定发送分区,具体发送的分区计算公式:hash(key)%partitionNum
ProducerRecord<String, String> producerRecord = new ProducerRecord<>(TOPIC, order.getId().toString(), JSON.toJSONString(order));
// 同步阻塞方法, 等待消息发送成功, send本质是异步的, 返回值是Future<RecordMetadata>, 通过get获取其最终结果
RecordMetadata metadata = producer.send(producerRecord).get();
System.out.println("同步方式发送消息结果:" + metadata);
// 异步发送, 不接收回调
// producer.send(producerRecord);
// 异步回调方式发送消息
// producer.send(producerRecord, new Callback() {
// public void onCompletion(RecordMetadata metadata, Exception exception) {
// if (exception != null) {
// System.err.println("发送消息失败:" + Arrays.toString(exception.getStackTrace()));
//
// }
// if (metadata != null) {
// System.out.println("异步方式发送消息结果:" + metadata);
// }
// countDownLatch.countDown();
// }
// });
}
// countDownLatch.await(5, TimeUnit.SECONDS);
producer.close();
}
}
消费者
package com.mrathena.kafka;
import org.apache.kafka.clients.consumer.*;
import org.apache.kafka.common.PartitionInfo;
import org.apache.kafka.common.TopicPartition;
import org.apache.kafka.common.serialization.StringDeserializer;
import java.time.Duration;
import java.util.*;
public class ConsumerTest {
private final static String TOPIC = "test-3-2-3";
private final static String GROUP = "group";
public static void main(String[] args) {
Properties properties = new Properties();
properties.put(ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG, "192.168.2.131:9092,192.168.2.132:9092,192.168.2.133:9092");
// 消费分组名
properties.put(ConsumerConfig.GROUP_ID_CONFIG, GROUP);
// 是否自动提交offset,默认就是true
// properties.put(ConsumerConfig.ENABLE_AUTO_COMMIT_CONFIG, "true");
// 自动提交offset的间隔时间, 每1000毫秒提交一次
// properties.put(ConsumerConfig.AUTO_COMMIT_INTERVAL_MS_CONFIG, "1000");
// 是否自动提交offset
properties.put(ConsumerConfig.ENABLE_AUTO_COMMIT_CONFIG, "false");
// 当消费主题的是一个新的消费组,或者指定offset的消费方式,offset不存在,那么应该如何消费
// latest(默认) :只消费自己启动之后才发送到主题的消息
// earliest:第一次从头开始消费,以后按照消费offset记录继续消费,这个需要区别于consumer.seekToBeginning(每次都从头开始消费)
properties.put(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG, "earliest");
// consumer给broker发送心跳的间隔时间,broker接收到心跳如果此时有rebalance发生会通过心跳响应将rebalance方案下发给consumer,这个时间可以稍微短一点
properties.put(ConsumerConfig.HEARTBEAT_INTERVAL_MS_CONFIG, 1000);
// broker接收不到一个consumer的心跳, 持续该时间, 就认为故障了,会将其踢出消费组,对应的Partition也会被重新分配给其他consumer,默认是10秒
properties.put(ConsumerConfig.SESSION_TIMEOUT_MS_CONFIG, 10 * 1000);
// 一次poll最大拉取消息的条数,如果消费者处理速度很快,可以设置大点,如果处理速度一般,可以设置小点
properties.put(ConsumerConfig.MAX_POLL_RECORDS_CONFIG, 100);
// 如果两次poll操作间隔超过了这个时间,broker就会认为这个consumer处理能力太弱,会将其踢出消费组,将分区分配给别的consumer消费
properties.put(ConsumerConfig.MAX_POLL_INTERVAL_MS_CONFIG, 30 * 1000);
// 把消息的key从字节数组反序列化为字符串
properties.put(ConsumerConfig.KEY_DESERIALIZER_CLASS_CONFIG, StringDeserializer.class.getName());
// 把消息的value从字节数组反序列化为字符串
properties.put(ConsumerConfig.VALUE_DESERIALIZER_CLASS_CONFIG, StringDeserializer.class.getName());
KafkaConsumer<String, String> consumer = new KafkaConsumer<>(properties);
// 订阅主题
consumer.subscribe(Collections.singletonList(TOPIC));
// 消费指定分区, 订阅主题:subscribe和分配分区:assign, 只需要一个就好, assign里已经包含了topic的信息了
// consumer.assign(Collections.singletonList(new TopicPartition(TOPIC, 0)));
// consumer.assign(Collections.singletonList(new TopicPartition(TOPIC, 1)));
// 消息回溯消费(每次都从log的最开始消费)
// consumer.assign(Collections.singletonList(new TopicPartition(TOPIC, 0)));
// consumer.seekToBeginning(Collections.singletonList(new TopicPartition(TOPIC, 0)));
// 指定offset起消费
// consumer.assign(Collections.singletonList(new TopicPartition(TOPIC, 0)));
// consumer.seek(new TopicPartition(TOPIC, 0), 37);
// 从指定时间点开始消费
/*List<PartitionInfo> topicPartitions = consumer.partitionsFor(TOPIC);
// 从3小时前开始消费
long fetchBeginAt = System.currentTimeMillis() - 1000 * 60 * 60 * 3;
// 确认每个分区的开始消费时刻
Map<TopicPartition, Long> topicPartitionBeginAtMap = new HashMap<>();
for (PartitionInfo partition : topicPartitions) {
topicPartitionBeginAtMap.put(new TopicPartition(TOPIC, partition.partition()), fetchBeginAt);
}
// 根据每个分区的开始消费时刻找到对应时刻的offset和timestamp
Map<TopicPartition, OffsetAndTimestamp> topicPartitionOffsetAndTimestampMap = consumer.offsetsForTimes(topicPartitionBeginAtMap);
for (Map.Entry<TopicPartition, OffsetAndTimestamp> entry : topicPartitionOffsetAndTimestampMap.entrySet()) {
// 轮流消费每个分区的指定起始offset的消息
TopicPartition key = entry.getKey();
OffsetAndTimestamp value = entry.getValue();
if (key == null || value == null) continue;
long offset = value.offset();
System.out.println("partition-" + key.partition() + "|offset-" + offset);
System.out.println();
// 根据消费里的timestamp确定offset
consumer.assign(Collections.singletonList(key));
consumer.seek(key, offset);
// 然后开始消费, 先不写了, 和下面的消费流程一样
}*/
while (true) {
// poll(duration): 长轮询, 即duration时段内没拿到消息就一直重复尝试拿, 知道时间到或者拿到消息才返回结果
ConsumerRecords<String, String> records = consumer.poll(Duration.ofMillis(1000));
for (ConsumerRecord<String, String> record : records) {
System.out.printf("收到消息:partition = %d,offset = %d, key = %s, value = %s%n", record.partition(), record.offset(), record.key(), record.value());
}
if (records.count() > 0) {
// 手动同步提交offset,当前线程会阻塞直到offset提交成功, 一般使用同步提交,因为提交之后一般也没有什么逻辑代码了
consumer.commitSync();
// 手动异步提交offset,当前线程提交offset不会阻塞,可以继续处理后面的程序逻辑
/*consumer.commitAsync(new OffsetCommitCallback() {
@Override
public void onComplete(Map<TopicPartition, OffsetAndMetadata> offsets, Exception exception) {
if (exception != null) {
System.err.println("Commit failed for " + offsets);
System.err.println("Commit failed exception: " + Arrays.toString(exception.getStackTrace()));
}
}
});*/
}
}
}
}