Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-11192

rockdb customize configuration Covered jobmaster

    XMLWordPrintableJSON

Details

    Description

      set state backends is rocksdb 

      set 'state.backend.rocksdb.timer-service.factory' by  Configuration not flink-conf.yaml

       

      
      RocksDBStateBackend backend = new RocksDBStateBackend(checkpointPath,true);
      Configuration configuration = new Configuration();
      configuration.setString(
         RocksDBOptions.TIMER_SERVICE_FACTORY,
         RocksDBStateBackend.PriorityQueueStateType.ROCKSDB.toString());
      backend = backend.configure(configuration);
      

       

       

      then submit the job by client

      but  the job runtime the 'TIMER_SERVICE_FACTORY'  Covered  by jobmaster

      RocksDBOptions.TIMER_SERVICE_FACTORY

      jobmaster code

      org.apache.flink.runtime.state.StateBackendLoader

       

      
      backend = ((ConfigurableStateBackend) fromApplication).configure(config);
      

       

       

      jobmaster  buildGraph  config is from flink-conf.yaml

      Final execution of the same method

      org.apache.flink.contrib.streaming.state.RocksDBStateBackend

       

      
      final String priorityQueueTypeString = config.getString(TIMER_SERVICE_FACTORY);
      
      this.priorityQueueStateType = priorityQueueTypeString.length() > 0 ?
         PriorityQueueStateType.valueOf(priorityQueueTypeString.toUpperCase()) : original.priorityQueueStateType;
      

       

       

      the problem is   config.getString(TIMER_SERVICE_FACTORY)   

      always have value regardless of configuration 

      so my customize  config by Covered by jobmatser 

       

       

      Attachments

        Issue Links

          Activity

            People

              Unassigned Unassigned
              fanweiwen Fan weiwen
              Votes:
              0 Vote for this issue
              Watchers:
              1 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: