Description
Fix findbugs multithreaded correctness warnings for streams
Multithreaded correctness Warnings
Code Warning
AT Sequence of calls to java.util.concurrent.ConcurrentHashMap may not be atomic in org.apache.kafka.streams.state.internals.Segments.getOrCreateSegment(long, ProcessorContext)
IS Inconsistent synchronization of org.apache.kafka.streams.KafkaStreams.stateListener; locked 66% of time
IS Inconsistent synchronization of org.apache.kafka.streams.processor.internals.StreamThread.stateListener; locked 66% of time
IS Inconsistent synchronization of org.apache.kafka.streams.processor.TopologyBuilder.applicationId; locked 50% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.CachingKeyValueStore.context; locked 66% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.CachingWindowStore.cache; locked 60% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.CachingWindowStore.context; locked 66% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.CachingWindowStore.name; locked 60% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.CachingWindowStore.serdes; locked 70% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.RocksDBStore.db; locked 63% of time
IS Inconsistent synchronization of org.apache.kafka.streams.state.internals.RocksDBStore.serdes; locked 76% of time
Attachments
Issue Links
- is related to
-
KAFKA-4773 The Kafka build should run findbugs
- Resolved
- relates to
-
KAFKA-4995 Fix remaining findbugs warnings in Kafka Streams
- Resolved
- links to