Uploaded image for project: 'Apache Drill'
  1. Apache Drill
  2. DRILL-7530

Fix class names in loggers

    XMLWordPrintableJSON

Details

    • Task
    • Status: Resolved
    • Major
    • Resolution: Fixed
    • 1.17.0
    • 1.18.0
    • None

    Description

      Some loggers have incorrect class names which leads to incorrect information in logs.
      This Jira aims to fix all occurrences of incorrect class names in loggers.

      Preliminary list (some occurrences will be excluded):

      Name: MapRDBTableCache.java. Expected: MapRDBTableCache. Got: MapRDBFormatPlugin.
      Name: HiveFuncHolderExpr.java. Expected: HiveFuncHolderExpr. Got: DrillFuncHolderExpr.
      Name: HiveFuncHolder.java. Expected: HiveFuncHolder. Got: FunctionImplementationRegistry.
      Name: HiveMetadataProvider.java. Expected: HiveMetadataProvider. Got: HiveStats.
      Name: TableEntryCacheLoader.java. Expected: TableEntryCacheLoader. Got: TableNameCacheLoader.
      Name: TestKafkaSuit.java. Expected: TestKafkaSuit. Got: LoggerFactory.
      Name: DrillTestWrapper.java. Expected: DrillTestWrapper. Got: BaseTestQuery.
      Name: TestDisabledFunctionality.java. Expected: TestDisabledFunctionality. Got: TestExampleQueries.
      Name: TestMergeJoin.java. Expected: TestMergeJoin. Got: HashAggBatch.
      Name: TestLateralJoinCorrectnessBatchProcessing.java. Expected: TestLateralJoinCorrectnessBatchProcessing. Got: TestNewLateralJoinCorrectness.
      Name: TestOperatorRecordBatch.java. Expected: TestOperatorRecordBatch. Got: SubOperatorTest.
      Name: TestPauseInjection.java. Expected: TestPauseInjection. Got: DummyClass.
      Name: TestComplexTypeWriter.java. Expected: TestComplexTypeWriter. Got: TestComplexTypeReader.
      Name: AvgIntervalTypeFunctions.java. Expected: AvgIntervalTypeFunctions. Got: AvgFunctions.
      Name: SSLConfigBuilder.java. Expected: SSLConfigBuilder. Got: org.apache.drill.exec.ssl.SSLConfigBuilder.
      Name: PlannerPhase.java. Expected: PlannerPhase. Got: DrillRuleSets.
      Name: AbstractIndexDescriptor.java. Expected: AbstractIndexDescriptor. Got: AbstractIndexDescriptor .
      Name: CoveringPlanNoFilterGenerator.java. Expected: CoveringPlanNoFilterGenerator. Got: CoveringIndexPlanGenerator.
      Name: AbstractSqlSetHandler.java. Expected: AbstractSqlSetHandler. Got: AbstractSqlHandler.
      Name: HashJoinMemoryCalculatorImpl.java. Expected: HashJoinMemoryCalculatorImpl. Got: BuildSidePartitioning.
      Name: HashJoinMemoryCalculatorImpl.java. Expected: HashJoinMemoryCalculatorImpl. Got: PostBuildCalculationsImpl.
      Name: HashJoinMemoryCalculator.java. Expected: HashJoinMemoryCalculator. Got: PartitionStatSet.
      Name: NestedLoopJoinTemplate.java. Expected: NestedLoopJoinTemplate. Got: NestedLoopJoinBatch.
      Name: PartitionLimitRecordBatch.java. Expected: PartitionLimitRecordBatch. Got: LimitRecordBatch.
      Name: HashAggTemplate.java. Expected: HashAggTemplate. Got: HashAggregator.
      Name: SpilledRecordbatch.java. Expected: SpilledRecordbatch. Got: SimpleRecordBatch.
      Name: StreamingAggTemplate.java. Expected: StreamingAggTemplate. Got: StreamingAggregator.
      Name: SortMemoryManager.java. Expected: SortMemoryManager. Got: ExternalSortBatch.
      Name: SortConfig.java. Expected: SortConfig. Got: ExternalSortBatch.
      Name: SortImpl.java. Expected: SortImpl. Got: ExternalSortBatch.
      Name: SingleSenderCreator.java. Expected: SingleSenderCreator. Got: SingleSenderRootExec.
      Name: HashTableTemplate.java. Expected: HashTableTemplate. Got: HashTable.
      Name: FrameSupportTemplate.java. Expected: FrameSupportTemplate. Got: NoFrameSupportTemplate.
      Name: ScreenCreator.java. Expected: ScreenCreator. Got: ScreenRoot.
      Name: UnionAll.java. Expected: UnionAll. Got: Filter.
      Name: AvgIntervalTypeFunctions.java. Expected: AvgIntervalTypeFunctions. Got: AvgFunctions.
      Name: PersistedOptionValue.java. Expected: PersistedOptionValue. Got: Deserializer.
      Name: ThreadsResources.java. Expected: ThreadsResources. Got: MetricsResources.
      Name: RepeatedVarCharOutput.java. Expected: RepeatedVarCharOutput. Got: BaseFieldOutput.
      Name: MockSubScanPOP.java. Expected: MockSubScanPOP. Got: MockGroupScanPOP.
      Name: InMemoryStore.java. Expected: InMemoryStore. Got: InMemoryPersistentStore.
      Name: ParquetColumnChunkPageWriteStore.java. Expected: ParquetColumnChunkPageWriteStore. Got: ParquetDirectByteBufferAllocator.
      Name: CorrelationTypeFunctions.java. Expected: CorrelationTypeFunctions. Got: ${aggrtype.className}Functions.
      Name: MathFunctionTemplates.java. Expected: MathFunctionTemplates. Got: ${inputType.className}Functions.
      Name: CastHigh.java. Expected: CastHigh. Got: CastHighFunctions.
      Name: IntervalAggrFunctions2.java. Expected: IntervalAggrFunctions2. Got: ${aggrtype.className}Functions.
      Name: SumZeroAggr.java. Expected: SumZeroAggr. Got: SumZeroFunctions.
      Name: NumericFunctionsTemplates.java. Expected: NumericFunctionsTemplates. Got: ${numericFunc.className}Functions.
      Name: CovarTypeFunctions.java. Expected: CovarTypeFunctions. Got: ${aggrtype.className}Functions.
      Name: AggrTypeFunctions3.java. Expected: AggrTypeFunctions3. Got: ${aggrtype.className}Functions.
      Name: AggrBitwiseLogicalTypeFunctions.java. Expected: AggrBitwiseLogicalTypeFunctions. Got: ${aggrtype.className}Functions.
      Name: AggrTypeFunctions2.java. Expected: AggrTypeFunctions2. Got: ${aggrtype.className}Functions.
      Name: MathFunctions.java. Expected: MathFunctions. Got: GMathFunctions.
      Name: MathFunctions.java. Expected: MathFunctions. Got: ExtendedMathFunctions.
      Name: MathFunctions.java. Expected: MathFunctions. Got: TrigoMathFunctions.
      

      Attachments

        Issue Links

          Activity

            People

              arina Arina Ielchiieva
              arina Arina Ielchiieva
              Vova Vysotskyi Vova Vysotskyi
              Votes:
              1 Vote for this issue
              Watchers:
              2 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: