Giriş
Kafka API'sini sağlar ancak C++ ile geliştirilmiştir. Maliyet
Redpanda kendisini Kafka işletme ve idamesine göre daha maliyet etkin olarak sunuyor
Docker
Örnek
Şöyle yaparız. Burada Redpanda ve Redpanda Console çalıştırılıyor
docker run -d \--pull=always \--name=redpanda \--hostname=redpanda \--net=redpanda \-p 8081:8081 \-p 8082:8082 \-p 9092:9092 \-p 9644:9644 \-v "redpanda1:/var/lib/redpanda/data" \vectorized/redpanda redpanda start \--overprovisioned \--smp 1 \--memory 1G \--reserve-memory 0M \--pandaproxy-addr INSIDE://0.0.0.0:28082,OUTSIDE://0.0.0.0:8082 \--advertise-pandaproxy-addr INSIDE://redpanda:28082,OUTSIDE://localhost:8082 \--kafka-addr INSIDE://redpanda:29092,OUTSIDE://0.0.0.0:9092 \--advertise-kafka-addr INSIDE://redpanda:29092,OUTSIDE://localhost:9092 \--rpc-addr 0.0.0.0:33145 \--advertise-rpc-addr redpanda:33145
Örnek
Şöyle yaparız. Burada sadece Redpanda çalıştırılıyor
docker run --network=redpanda \ --name=console \ -e KAFKA_BROKERS=redpanda:29092 \ -p 8080:8080 \ docker.redpanda.com/vectorized/console:latest
Altta Seastar
Altta Seastar çatısını kullanır. Açıklaması şöyle
Redpanda is a source available Kafka clone written in C++ using the Seastar framework from ScyllaDB, a wide-column database. It uses the popular Raft consensus protocol for replication and all distributed consensus logic.
Yapısal Olarak Kafka'ya Çok Benzer
Açıklaması şöyle.
Performans KarşılaştırmasıThe interesting thing about Redpanda and Kafka is that they are both distributed, append-only log systems that typically have a replication factor of 3, are both leader-follower based and use the same client protocol. Additionally both chose to map one partition to one active segment file rather than use a shared-log storage model such as Apache Pulsar and Pravega. For the same throughput, they write the same amount of data to disk (to the same number of files) and they transmit the same amount of data over the network.
Bu kadar benzerlik varken sadece C++ kullandığı için daha hızlı olup olmadığını ölçen bir yazı burada. Yazıya göre Redpanda Kafka'dan daha hızlı değil
No comments:
Post a Comment