public class CollectorStartupEvent extends MetadataCollectorEvent
CacheBuildEvent
to build the topic MetadataEvent cache in the context.CACHE_BUILD_EVENT_TAG, collector, eventObservedTimeMillis, LOG, SNAPSHOT_EVENT_TAG, time
Constructor and Description |
---|
CollectorStartupEvent(ZKTopicMetadataCollector collector,
ZKTopicMetadataCollectorConfig config,
Map<String,TopicInfo> initialTopicsWithInfo,
MetadataCollectorEventQueue eventQueue,
org.apache.kafka.common.metrics.Metrics metrics,
kafka.zk.KafkaZkClient zkClient,
kafka.server.KafkaConfig originalConfig,
int epoch,
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 CollectorStartupEvent(ZKTopicMetadataCollector collector, ZKTopicMetadataCollectorConfig config, Map<String,TopicInfo> initialTopicsWithInfo, MetadataCollectorEventQueue eventQueue, org.apache.kafka.common.metrics.Metrics metrics, kafka.zk.KafkaZkClient zkClient, kafka.server.KafkaConfig originalConfig, int epoch, 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