public class TopicConfigChangeEvent extends MetadataCollectorEvent
TopicConfigChangeEvent
:
1. adding a dynamic topic config
2. deleting a dynamic topic config
The event will handle both type of changes and reflect the topic config change in the
LocalStore
, and emit an incremental event for the change.CACHE_BUILD_EVENT_TAG, collector, eventObservedTimeMillis, LOG, SNAPSHOT_EVENT_TAG, time
Constructor and Description |
---|
TopicConfigChangeEvent(ZKTopicMetadataCollector collector,
String logicalClusterId,
String topic,
kafka.log.LogConfig newConfig,
Properties updateProperties,
org.apache.kafka.common.utils.Time time) |
Modifier and Type | Method and Description |
---|---|
void |
handleException(Throwable e) |
void |
run() |
String |
toString() |
context, emitDeltaEvent, emitSnapshotEvent, filterCatalogConfigOverride, getLogConfigsForTopic, getTopicIdReplicaAssignmentFromZk, recordEventHandleError
public TopicConfigChangeEvent(ZKTopicMetadataCollector collector, String logicalClusterId, String topic, kafka.log.LogConfig newConfig, Properties updateProperties, org.apache.kafka.common.utils.Time time)
public void handleException(Throwable e)
handleException
in interface org.apache.kafka.queue.EventQueue.Event
handleException
in class MetadataCollectorEvent