You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@kafka.apache.org by vishnu murali <vi...@gmail.com> on 2020/07/20 15:39:22 UTC

Problem while sending data

Hi all

I am trying to send the data from Kafka Java producer in the format of Avro

While trying to  send  data it is not sent.

Before and after statement of send is executing correctly.But that sending
alone is not working

But it register the schema successfully..


No logs or error message is there !!!

Other Kafka applications are working fine ..

Does anyone have any idea on this??

20:02:14.059 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Initiating connection to node localhost:9092 (id: -1 rack: null) using
address localhost/127.0.0.1

20:02:14.062 [main] DEBUG org.apache.kafka.clients.producer.KafkaProducer -
[Producer clientId=producer-1] Kafka producer started

20:02:14.075 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.common.network.Selector - [Producer clientId=producer-1]
Created socket with SO_RCVBUF = 32768, SO_SNDBUF = 131072, SO_TIMEOUT = 0
to node -1

20:02:14.217 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Completed connection to node -1. Fetching API versions.

20:02:14.217 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Initiating API versions fetch from node -1.

20:02:14.345 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Recorded API versions for node -1: (Produce(0): 0 to 8 [usable: 8],
Fetch(1): 0 to 11 [usable: 11], ListOffsets(2): 0 to 5 [usable: 5],
Metadata(3): 0 to 9 [usable: 9], LeaderAndIsr(4): 0 to 4 [usable: 4],
StopReplica(5): 0 to 2 [usable: 2], UpdateMetadata(6): 0 to 6 [usable: 6],
ControlledShutdown(7): 0 to 3 [usable: 3], OffsetCommit(8): 0 to 8 [usable:
8], OffsetFetch(9): 0 to 7 [usable: 6], FindCoordinator(10): 0 to 3
[usable: 3], JoinGroup(11): 0 to 7 [usable: 6], Heartbeat(12): 0 to 4
[usable: 4], LeaveGroup(13): 0 to 4 [usable: 4], SyncGroup(14): 0 to 5
[usable: 4], DescribeGroups(15): 0 to 5 [usable: 5], ListGroups(16): 0 to 3
[usable: 3], SaslHandshake(17): 0 to 1 [usable: 1], ApiVersions(18): 0 to 3
[usable: 3], CreateTopics(19): 0 to 5 [usable: 5], DeleteTopics(20): 0 to 4
[usable: 4], DeleteRecords(21): 0 to 1 [usable: 1], InitProducerId(22): 0
to 3 [usable: 2], OffsetForLeaderEpoch(23): 0 to 3 [usable: 3],
AddPartitionsToTxn(24): 0 to 1 [usable: 1], AddOffsetsToTxn(25): 0 to 1
[usable: 1], EndTxn(26): 0 to 1 [usable: 1], WriteTxnMarkers(27): 0
[usable: 0], TxnOffsetCommit(28): 0 to 3 [usable: 2], DescribeAcls(29): 0
to 2 [usable: 1], CreateAcls(30): 0 to 2 [usable: 1], DeleteAcls(31): 0 to
2 [usable: 1], DescribeConfigs(32): 0 to 2 [usable: 2], AlterConfigs(33): 0
to 1 [usable: 1], AlterReplicaLogDirs(34): 0 to 1 [usable: 1],
DescribeLogDirs(35): 0 to 1 [usable: 1], SaslAuthenticate(36): 0 to 2
[usable: 1], CreatePartitions(37): 0 to 2 [usable: 1],
CreateDelegationToken(38): 0 to 2 [usable: 2], RenewDelegationToken(39): 0
to 2 [usable: 1], ExpireDelegationToken(40): 0 to 2 [usable: 1],
DescribeDelegationToken(41): 0 to 2 [usable: 1], DeleteGroups(42): 0 to 2
[usable: 2], ElectLeaders(43): 0 to 2 [usable: 2],
IncrementalAlterConfigs(44): 0 to 1 [usable: 1],
AlterPartitionReassignments(45): 0 [usable: 0],
ListPartitionReassignments(46): 0 [usable: 0], OffsetDelete(47): 0 [usable:
0], UNKNOWN(10000): 0)

20:02:14.346 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Sending metadata request MetadataRequestData(topics=[],
allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
includeTopicAuthorizedOperations=false) to node localhost:9092 (id: -1
rack: null)

20:02:14.357 [kafka-producer-network-thread | producer-1] INFO
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Cluster
ID: ugUXR7FWR7uXIGWcpJYdLA

20:02:14.357 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
cluster metadata updateVersion 2 to
MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
(id: 1 rack: null)], partitions=[], controller=localhost:9092 (id: 1 rack:
null)}


*GOING TO INSERT*

20:02:14.386 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Initialize connection to node localhost:9092 (id: 1 rack: null) for sending
metadata request

20:02:14.386 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Initiating connection to node localhost:9092 (id: 1 rack: null) using
address localhost/127.0.0.1

20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.common.network.Selector - [Producer clientId=producer-1]
Created socket with SO_RCVBUF = 32768, SO_SNDBUF = 131072, SO_TIMEOUT = 0
to node 1

20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Completed connection to node 1. Fetching API versions.

20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Initiating API versions fetch from node 1.

20:02:14.391 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Recorded API versions for node 1: (Produce(0): 0 to 8 [usable: 8],
Fetch(1): 0 to 11 [usable: 11], ListOffsets(2): 0 to 5 [usable: 5],
Metadata(3): 0 to 9 [usable: 9], LeaderAndIsr(4): 0 to 4 [usable: 4],
StopReplica(5): 0 to 2 [usable: 2], UpdateMetadata(6): 0 to 6 [usable: 6],
ControlledShutdown(7): 0 to 3 [usable: 3], OffsetCommit(8): 0 to 8 [usable:
8], OffsetFetch(9): 0 to 7 [usable: 6], FindCoordinator(10): 0 to 3
[usable: 3], JoinGroup(11): 0 to 7 [usable: 6], Heartbeat(12): 0 to 4
[usable: 4], LeaveGroup(13): 0 to 4 [usable: 4], SyncGroup(14): 0 to 5
[usable: 4], DescribeGroups(15): 0 to 5 [usable: 5], ListGroups(16): 0 to 3
[usable: 3], SaslHandshake(17): 0 to 1 [usable: 1], ApiVersions(18): 0 to 3
[usable: 3], CreateTopics(19): 0 to 5 [usable: 5], DeleteTopics(20): 0 to 4
[usable: 4], DeleteRecords(21): 0 to 1 [usable: 1], InitProducerId(22): 0
to 3 [usable: 2], OffsetForLeaderEpoch(23): 0 to 3 [usable: 3],
AddPartitionsToTxn(24): 0 to 1 [usable: 1], AddOffsetsToTxn(25): 0 to 1
[usable: 1], EndTxn(26): 0 to 1 [usable: 1], WriteTxnMarkers(27): 0
[usable: 0], TxnOffsetCommit(28): 0 to 3 [usable: 2], DescribeAcls(29): 0
to 2 [usable: 1], CreateAcls(30): 0 to 2 [usable: 1], DeleteAcls(31): 0 to
2 [usable: 1], DescribeConfigs(32): 0 to 2 [usable: 2], AlterConfigs(33): 0
to 1 [usable: 1], AlterReplicaLogDirs(34): 0 to 1 [usable: 1],
DescribeLogDirs(35): 0 to 1 [usable: 1], SaslAuthenticate(36): 0 to 2
[usable: 1], CreatePartitions(37): 0 to 2 [usable: 1],
CreateDelegationToken(38): 0 to 2 [usable: 2], RenewDelegationToken(39): 0
to 2 [usable: 1], ExpireDelegationToken(40): 0 to 2 [usable: 1],
DescribeDelegationToken(41): 0 to 2 [usable: 1], DeleteGroups(42): 0 to 2
[usable: 2], ElectLeaders(43): 0 to 2 [usable: 2],
IncrementalAlterConfigs(44): 0 to 1 [usable: 1],
AlterPartitionReassignments(45): 0 [usable: 0],
ListPartitionReassignments(46): 0 [usable: 0], OffsetDelete(47): 0 [usable:
0], UNKNOWN(10000): 0)

20:02:14.391 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Sending metadata request
MetadataRequestData(topics=[MetadataRequestTopic(name='t-ord3')],
allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
includeTopicAuthorizedOperations=false) to node localhost:9092 (id: 1 rack:
null)

20:02:14.451 [kafka-producer-network-thread | producer-1] WARN
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Error while fetching metadata with correlation id 3 :
{t-ord3=LEADER_NOT_AVAILABLE}

20:02:14.451 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1]
Requesting metadata update for topic t-ord3 due to error
LEADER_NOT_AVAILABLE

20:02:14.451 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
cluster metadata updateVersion 3 to
MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
(id: 1 rack: null)], partitions=[], controller=localhost:9092 (id: 1 rack:
null)}

20:02:14.551 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Sending metadata request
MetadataRequestData(topics=[MetadataRequestTopic(name='t-ord3')],
allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
includeTopicAuthorizedOperations=false) to node localhost:9092 (id: 1 rack:
null)

20:02:14.553 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updating
last seen epoch from null to 0 for partition t-ord3-0

20:02:14.554 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
cluster metadata updateVersion 4 to
MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
(id: 1 rack: null)],
partitions=[PartitionInfoAndEpoch{partitionInfo=Partition(topic = t-ord3,
partition = 0, leader = 1, replicas = [1], isr = [1], offlineReplicas =
[]), epoch=0}], controller=localhost:9092 (id: 1 rack: null)}

20:02:14.591 [main] DEBUG
io.confluent.kafka.schemaregistry.client.rest.RestService - Sending POST
with input {"schema":"{\"type\":\"record………….


*AFTER INSERT*

Re: Problem while sending data

Posted by Ricardo Ferreira <ri...@riferrei.com>.
Here is the problem:

20:02:14.451 [kafka-producer-network-thread | producer-1] WARN
org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
Error while fetching metadata with correlation id 3 :
{t-ord3=LEADER_NOT_AVAILABLE}

20:02:14.451 [kafka-producer-network-thread | producer-1] DEBUG
org.apache.kafka.clients.Metadata - [Producer clientId=producer-1]
Requesting metadata update for topic t-ord3 due to error
LEADER_NOT_AVAILABLE

If the leader of the partition is not available then no writes are 
permitted. Now why the leader is not available is something that from 
the producer perspective you won't be able to investigate. Make sure 
you're monitoring leader elections, broker unavailability, ZK 
availability/slowness, etc.

-- Ricardo

On 7/20/20 11:39 AM, vishnu murali wrote:
> Hi all
>
> I am trying to send the data from Kafka Java producer in the format of Avro
>
> While trying to  send  data it is not sent.
>
> Before and after statement of send is executing correctly.But that sending
> alone is not working
>
> But it register the schema successfully..
>
>
> No logs or error message is there !!!
>
> Other Kafka applications are working fine ..
>
> Does anyone have any idea on this??
>
> 20:02:14.059 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Initiating connection to node localhost:9092 (id: -1 rack: null) using
> address localhost/127.0.0.1
>
> 20:02:14.062 [main] DEBUG org.apache.kafka.clients.producer.KafkaProducer -
> [Producer clientId=producer-1] Kafka producer started
>
> 20:02:14.075 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.common.network.Selector - [Producer clientId=producer-1]
> Created socket with SO_RCVBUF = 32768, SO_SNDBUF = 131072, SO_TIMEOUT = 0
> to node -1
>
> 20:02:14.217 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Completed connection to node -1. Fetching API versions.
>
> 20:02:14.217 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Initiating API versions fetch from node -1.
>
> 20:02:14.345 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Recorded API versions for node -1: (Produce(0): 0 to 8 [usable: 8],
> Fetch(1): 0 to 11 [usable: 11], ListOffsets(2): 0 to 5 [usable: 5],
> Metadata(3): 0 to 9 [usable: 9], LeaderAndIsr(4): 0 to 4 [usable: 4],
> StopReplica(5): 0 to 2 [usable: 2], UpdateMetadata(6): 0 to 6 [usable: 6],
> ControlledShutdown(7): 0 to 3 [usable: 3], OffsetCommit(8): 0 to 8 [usable:
> 8], OffsetFetch(9): 0 to 7 [usable: 6], FindCoordinator(10): 0 to 3
> [usable: 3], JoinGroup(11): 0 to 7 [usable: 6], Heartbeat(12): 0 to 4
> [usable: 4], LeaveGroup(13): 0 to 4 [usable: 4], SyncGroup(14): 0 to 5
> [usable: 4], DescribeGroups(15): 0 to 5 [usable: 5], ListGroups(16): 0 to 3
> [usable: 3], SaslHandshake(17): 0 to 1 [usable: 1], ApiVersions(18): 0 to 3
> [usable: 3], CreateTopics(19): 0 to 5 [usable: 5], DeleteTopics(20): 0 to 4
> [usable: 4], DeleteRecords(21): 0 to 1 [usable: 1], InitProducerId(22): 0
> to 3 [usable: 2], OffsetForLeaderEpoch(23): 0 to 3 [usable: 3],
> AddPartitionsToTxn(24): 0 to 1 [usable: 1], AddOffsetsToTxn(25): 0 to 1
> [usable: 1], EndTxn(26): 0 to 1 [usable: 1], WriteTxnMarkers(27): 0
> [usable: 0], TxnOffsetCommit(28): 0 to 3 [usable: 2], DescribeAcls(29): 0
> to 2 [usable: 1], CreateAcls(30): 0 to 2 [usable: 1], DeleteAcls(31): 0 to
> 2 [usable: 1], DescribeConfigs(32): 0 to 2 [usable: 2], AlterConfigs(33): 0
> to 1 [usable: 1], AlterReplicaLogDirs(34): 0 to 1 [usable: 1],
> DescribeLogDirs(35): 0 to 1 [usable: 1], SaslAuthenticate(36): 0 to 2
> [usable: 1], CreatePartitions(37): 0 to 2 [usable: 1],
> CreateDelegationToken(38): 0 to 2 [usable: 2], RenewDelegationToken(39): 0
> to 2 [usable: 1], ExpireDelegationToken(40): 0 to 2 [usable: 1],
> DescribeDelegationToken(41): 0 to 2 [usable: 1], DeleteGroups(42): 0 to 2
> [usable: 2], ElectLeaders(43): 0 to 2 [usable: 2],
> IncrementalAlterConfigs(44): 0 to 1 [usable: 1],
> AlterPartitionReassignments(45): 0 [usable: 0],
> ListPartitionReassignments(46): 0 [usable: 0], OffsetDelete(47): 0 [usable:
> 0], UNKNOWN(10000): 0)
>
> 20:02:14.346 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Sending metadata request MetadataRequestData(topics=[],
> allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
> includeTopicAuthorizedOperations=false) to node localhost:9092 (id: -1
> rack: null)
>
> 20:02:14.357 [kafka-producer-network-thread | producer-1] INFO
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Cluster
> ID: ugUXR7FWR7uXIGWcpJYdLA
>
> 20:02:14.357 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
> cluster metadata updateVersion 2 to
> MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
> (id: 1 rack: null)], partitions=[], controller=localhost:9092 (id: 1 rack:
> null)}
>
>
> *GOING TO INSERT*
>
> 20:02:14.386 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Initialize connection to node localhost:9092 (id: 1 rack: null) for sending
> metadata request
>
> 20:02:14.386 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Initiating connection to node localhost:9092 (id: 1 rack: null) using
> address localhost/127.0.0.1
>
> 20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.common.network.Selector - [Producer clientId=producer-1]
> Created socket with SO_RCVBUF = 32768, SO_SNDBUF = 131072, SO_TIMEOUT = 0
> to node 1
>
> 20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Completed connection to node 1. Fetching API versions.
>
> 20:02:14.389 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Initiating API versions fetch from node 1.
>
> 20:02:14.391 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Recorded API versions for node 1: (Produce(0): 0 to 8 [usable: 8],
> Fetch(1): 0 to 11 [usable: 11], ListOffsets(2): 0 to 5 [usable: 5],
> Metadata(3): 0 to 9 [usable: 9], LeaderAndIsr(4): 0 to 4 [usable: 4],
> StopReplica(5): 0 to 2 [usable: 2], UpdateMetadata(6): 0 to 6 [usable: 6],
> ControlledShutdown(7): 0 to 3 [usable: 3], OffsetCommit(8): 0 to 8 [usable:
> 8], OffsetFetch(9): 0 to 7 [usable: 6], FindCoordinator(10): 0 to 3
> [usable: 3], JoinGroup(11): 0 to 7 [usable: 6], Heartbeat(12): 0 to 4
> [usable: 4], LeaveGroup(13): 0 to 4 [usable: 4], SyncGroup(14): 0 to 5
> [usable: 4], DescribeGroups(15): 0 to 5 [usable: 5], ListGroups(16): 0 to 3
> [usable: 3], SaslHandshake(17): 0 to 1 [usable: 1], ApiVersions(18): 0 to 3
> [usable: 3], CreateTopics(19): 0 to 5 [usable: 5], DeleteTopics(20): 0 to 4
> [usable: 4], DeleteRecords(21): 0 to 1 [usable: 1], InitProducerId(22): 0
> to 3 [usable: 2], OffsetForLeaderEpoch(23): 0 to 3 [usable: 3],
> AddPartitionsToTxn(24): 0 to 1 [usable: 1], AddOffsetsToTxn(25): 0 to 1
> [usable: 1], EndTxn(26): 0 to 1 [usable: 1], WriteTxnMarkers(27): 0
> [usable: 0], TxnOffsetCommit(28): 0 to 3 [usable: 2], DescribeAcls(29): 0
> to 2 [usable: 1], CreateAcls(30): 0 to 2 [usable: 1], DeleteAcls(31): 0 to
> 2 [usable: 1], DescribeConfigs(32): 0 to 2 [usable: 2], AlterConfigs(33): 0
> to 1 [usable: 1], AlterReplicaLogDirs(34): 0 to 1 [usable: 1],
> DescribeLogDirs(35): 0 to 1 [usable: 1], SaslAuthenticate(36): 0 to 2
> [usable: 1], CreatePartitions(37): 0 to 2 [usable: 1],
> CreateDelegationToken(38): 0 to 2 [usable: 2], RenewDelegationToken(39): 0
> to 2 [usable: 1], ExpireDelegationToken(40): 0 to 2 [usable: 1],
> DescribeDelegationToken(41): 0 to 2 [usable: 1], DeleteGroups(42): 0 to 2
> [usable: 2], ElectLeaders(43): 0 to 2 [usable: 2],
> IncrementalAlterConfigs(44): 0 to 1 [usable: 1],
> AlterPartitionReassignments(45): 0 [usable: 0],
> ListPartitionReassignments(46): 0 [usable: 0], OffsetDelete(47): 0 [usable:
> 0], UNKNOWN(10000): 0)
>
> 20:02:14.391 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Sending metadata request
> MetadataRequestData(topics=[MetadataRequestTopic(name='t-ord3')],
> allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
> includeTopicAuthorizedOperations=false) to node localhost:9092 (id: 1 rack:
> null)
>
> 20:02:14.451 [kafka-producer-network-thread | producer-1] WARN
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Error while fetching metadata with correlation id 3 :
> {t-ord3=LEADER_NOT_AVAILABLE}
>
> 20:02:14.451 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1]
> Requesting metadata update for topic t-ord3 due to error
> LEADER_NOT_AVAILABLE
>
> 20:02:14.451 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
> cluster metadata updateVersion 3 to
> MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
> (id: 1 rack: null)], partitions=[], controller=localhost:9092 (id: 1 rack:
> null)}
>
> 20:02:14.551 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.NetworkClient - [Producer clientId=producer-1]
> Sending metadata request
> MetadataRequestData(topics=[MetadataRequestTopic(name='t-ord3')],
> allowAutoTopicCreation=true, includeClusterAuthorizedOperations=false,
> includeTopicAuthorizedOperations=false) to node localhost:9092 (id: 1 rack:
> null)
>
> 20:02:14.553 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updating
> last seen epoch from null to 0 for partition t-ord3-0
>
> 20:02:14.554 [kafka-producer-network-thread | producer-1] DEBUG
> org.apache.kafka.clients.Metadata - [Producer clientId=producer-1] Updated
> cluster metadata updateVersion 4 to
> MetadataCache{clusterId='ugUXR7FWR7uXIGWcpJYdLA', nodes=[localhost:9092
> (id: 1 rack: null)],
> partitions=[PartitionInfoAndEpoch{partitionInfo=Partition(topic = t-ord3,
> partition = 0, leader = 1, replicas = [1], isr = [1], offlineReplicas =
> []), epoch=0}], controller=localhost:9092 (id: 1 rack: null)}
>
> 20:02:14.591 [main] DEBUG
> io.confluent.kafka.schemaregistry.client.rest.RestService - Sending POST
> with input {"schema":"{\"type\":\"record………….
>
>
> *AFTER INSERT*
>