Cause all that matters here is passing the Confluent CCDAK exam. Cause all that you need is a high score of CCDAK Confluent Certified Developer for Apache Kafka Certification Examination exam. The only one thing you need to do is downloading Passleader CCDAK exam study guides now. We will not let you down with our money-back guarantee.

Free CCDAK Demo Online For Confluent Certifitcation:

NEW QUESTION 1
A consumer is configured with enable.auto.commit=false. What happens when close() is called on the consumer object?

  • A. The uncommitted offsets are committed
  • B. A rebalance in the consumer group will happen immediately
  • C. The group coordinator will discover that the consumer stopped sending heartbeat
  • D. It will cause rebalance after session.timeout.ms

Answer: B

Explanation:
Calling close() on consumer immediately triggers a partition rebalance as the consumer will not be available anymore.

NEW QUESTION 2
Which of the following errors are retriable from a producer perspective? (select two)

  • A. MESSAGE_TOO_LARGE
  • B. INVALID_REQUIRED_ACKS
  • C. NOT_ENOUGH_REPLICAS
  • D. NOT_LEADER_FOR_PARTITION
  • E. TOPIC_AUTHORIZATION_FAILED

Answer: CD

Explanation:
Both of these are retriable errors, others non-retriable errors. See the full list of errors and their "retriable" status herehttps://kafka.apache.org/protocol#protocol_error_codes

NEW QUESTION 3
How does a consumer commit offsets in Kafka?

  • A. It directly sends a message to the consumer_offsets topic
  • B. It interacts with the Group Coordinator broker
  • C. It directly commits the offsets in Zookeeper

Answer: B

Explanation:
Consumers do not directly write to the consumer_offsets topic, they instead interact with a broker that has been elected to manage that topic, which is the Group Coordinator broker

NEW QUESTION 4
Which actions will trigger partition rebalance for a consumer group? (select three)

  • A. Increase partitions of a topic
  • B. Remove a broker from the cluster
  • C. Add a new consumer to consumer group
  • D. A consumer in a consumer group shuts down Add a broker to the cluster

Answer: ACD

Explanation:
Rebalance occurs when a new consumer is added, removed or consumer dies or paritions increased.

NEW QUESTION 5
Using the Confluent Schema Registry, where are Avro schema stored?

  • A. In the Schema Registry embedded SQL database
  • B. In the Zookeeper node /schemas
  • C. In the message bytes themselves
  • D. In the _schemas topic

Answer: D

Explanation:
The Schema Registry stores all the schemas in the _schemas Kafka topic

NEW QUESTION 6
A client connects to a broker in the cluster and sends a fetch request for a partition in a topic. It gets an exception Not Leader For Partition Exception in the response. How does client handle this situation?

  • A. Get the Broker id from Zookeeper that is hosting the leader replica and send request to it
  • B. Send metadata request to the same broker for the topic and select the broker hosting the leader replica
  • C. Send metadata request to Zookeeper for the topic and select the broker hosting the leader replica
  • D. Send fetch request to each Broker in the cluster

Answer: B

Explanation:
In case the consumer has the wrong leader of a partition, it will issue a metadata request. The Metadata request can be handled by any node, so clients know afterwards which broker are the designated leader for the topic partitions. Produce and consume requests can only be sent to the node hosting partition leader.

NEW QUESTION 7
To transform data from a Kafka topic to another one, I should use

  • A. Kafka Connect Sink
  • B. Kafka Connect Source
  • C. Consumer + Producer
  • D. Kafka Streams

Answer: D

Explanation:
Kafka Streams is a library for building streaming applications, specifically applications that transform input Kafka topics into output Kafka topics

NEW QUESTION 8
In Avro, adding a field to a record without default is a schema evolution

  • A. forward
  • B. backward
  • C. full
  • D. breaking

Answer: A

Explanation:
Clients with old schema will be able to read records saved with new schema.

NEW QUESTION 9
A consumer wants to read messages from a specific partition of a topic. How can this be achieved?

  • A. Call subscribe(String topic, int partition) passing the topic and partition number as the arguments
  • B. Call assign() passing a Collection of TopicPartitions as the argument
  • C. Call subscribe() passing TopicPartition as the argument

Answer: B

Explanation:
assign() can be used for manual assignment of a partition to a consumer, in which case subscribe() must not be used. Assign() takes a collection of TopicPartition object as an argument https://kafka.apache.org/23/javadoc/org/apache/kafka/clients/consumer/KafkaConsumer.ht
ml#assign-java.util.Collection-

NEW QUESTION 10
A producer is sending messages with null key to a topic with 6 partitions using the DefaultPartitioner. Where will the messages be stored?

  • A. Partition 5
  • B. Any of the topic partitions
  • C. The partition for the null key
  • D. Partition 0

Answer: A

Explanation:
Message with no keys will be stored with round-robin strategy among partitions.

NEW QUESTION 11
You are using JDBC source connector to copy data from 3 tables to three Kafka topics. There is one connector created with max.tasks equal to 2 deployed on a cluster of 3 workers. How many tasks are launched?

  • A. 2
  • B. 1
  • C. 3
  • D. 6

Answer: A

Explanation:
here, we have three tables, but the max.tasks is 2, so that's the maximum number of tasks that will be created

NEW QUESTION 12
Which of the following event processing application is stateless? (select two)

  • A. Read events from a stream and modifies them from JSON to Avro
  • B. Publish the top 10 stocks each day
  • C. Read log messages from a stream and writes ERROR events into a high-priority stream and the rest of the events into a low-priority stream
  • D. Find the minimum and maximum stock prices for each day of trading

Answer: AC

Explanation:
Stateless means processing of each message depends only on the message, so converting from JSON to Avro or filtering a stream are both stateless operations

NEW QUESTION 13
What is true about replicas ?

  • A. Produce requests can be done to the replicas that are followers
  • B. Produce and consume requests are load-balanced between Leader and Follower replicas
  • C. Leader replica handles all produce and consume requests
  • D. Follower replica handles all consume requests

Answer: C

Explanation:
Replicas are passive - they don't handle produce or consume request. Produce and consume requests get sent to the node hosting partition leader.

NEW QUESTION 14
Two consumers share the same group.id (consumer group id). Each consumer will

  • A. Read mutually exclusive offsets blocks on all the partitions
  • B. Read all the data on mutual exclusive partitions
  • C. Read all data from all partitions

Answer: B

Explanation:
Each consumer is assigned a different partition of the topic to consume.

NEW QUESTION 15
How will you read all the messages from a topic in your KSQL query?

  • A. KSQL reads from the beginning of a topic, by default.
  • B. KSQL reads from the end of a topi
  • C. This cannot be changed.
  • D. Use KSQL CLI to set auto.offset.reset property to earliest

Answer: C

Explanation:
Consumers can set auto.offset.reset property to earliest to start consuming from beginning. For KSQL, SET 'auto.offset.reset'='earliest';

NEW QUESTION 16
Which of the following setting increases the chance of batching for a Kafka Producer?

  • A. Increase batch.size
  • B. Increase message.max.bytes
  • C. Increase the number of producer threads
  • D. Increase linger.ms

Answer: D

Explanation:
linger.ms forces the producer to wait to send messages, hence increasing the chance of creating batches

NEW QUESTION 17
When is the onCompletion() method called?
private class ProducerCallback implements Callback {
@Override
public void onCompletion(RecordMetadata recordMetadata, Exception e) { if (e != null) {

  • A. e.printStackTrace();}}}ProducerRecord<String, String> record =new ProducerRecord<>("topic1", "key1", "value1"); producer.send(record, new ProducerCallback());
  • B. When the message is partitioned and batched successfully
  • C. When message is serialized successfully
  • D. When the broker response is received
  • E. When send() method is called

Answer: C

Explanation:
Callback is invoked when a broker response is received.

NEW QUESTION 18
......

100% Valid and Newest Version CCDAK Questions & Answers shared by Allfreedumps.com, Get Full Dumps HERE: https://www.allfreedumps.com/CCDAK-dumps.html (New 150 Q&As)