Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-4996

Fix findbugs multithreaded correctness warnings for streams

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • None
    • None
    • streams

    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

          Activity

            People

              lthomas Leah Thomas
              cmccabe Colin McCabe
              Votes:
              0 Vote for this issue
              Watchers:
              5 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: