├── .github ├── ISSUE_TEMPLATE │ ├── bug_report.md │ ├── documentation-request.md │ ├── feature_request.md │ └── submit-question.md ├── PULL_REQUEST_TEMPLATE.md ├── labeler.yml └── workflows │ ├── add-to-project.yml │ ├── configuration.json │ ├── labeler.yml │ ├── license-header-check.yml │ ├── markdown-links-check.yml │ ├── markdown-links-check │ └── markdown-links-check-config.json │ ├── mvn-verify-check.yml │ ├── python-unit-test.yml │ ├── release.yml │ ├── shell-check.yml │ └── signoff-check.yml ├── .gitignore ├── .pre-commit-config.yaml ├── .pylintrc ├── CHANGELOG.md ├── CONTRIBUTING.md ├── LICENSE ├── NOTICE ├── NOTICE-binary ├── README.md ├── SECURITY.md ├── core ├── .gitignore ├── README.md ├── docs │ ├── qual_core_output.md │ └── sampleFiles │ │ ├── bootstrap │ │ └── customTuningConfigs.yaml │ │ └── targetClusterInfo │ │ ├── targetCluster01.yaml │ │ ├── targetCluster02.yaml │ │ ├── targetCluster03.yaml │ │ ├── targetCluster04.yaml │ │ ├── targetCluster05.yaml │ │ ├── targetCluster06.yaml │ │ └── targetCluster07.yaml ├── pom.xml ├── scalastyle-config.xml └── src │ ├── main │ ├── resources │ │ ├── bootstrap │ │ │ ├── tuningConfigs.yaml │ │ │ └── tuningTable.yaml │ │ ├── configs │ │ │ ├── build.properties │ │ │ └── reports │ │ │ │ ├── coreRawMetricsReport.yaml │ │ │ │ ├── profCoreReport.yaml │ │ │ │ ├── qualCoreReport.yaml │ │ │ │ └── qualOutputTable.yaml │ │ ├── operatorsScore-databricks-aws-a10G.csv │ │ ├── operatorsScore-databricks-aws-t4.csv │ │ ├── operatorsScore-databricks-azure-t4.csv │ │ ├── operatorsScore-dataproc-gke-l4.csv │ │ ├── operatorsScore-dataproc-gke-t4.csv │ │ ├── operatorsScore-dataproc-l4.csv │ │ ├── operatorsScore-dataproc-serverless-l4.csv │ │ ├── operatorsScore-dataproc-t4.csv │ │ ├── operatorsScore-emr-a10.csv │ │ ├── operatorsScore-emr-a10G.csv │ │ ├── operatorsScore-emr-t4.csv │ │ ├── operatorsScore-onprem-a100.csv │ │ ├── parser │ │ │ └── eventlog-parser.yaml │ │ ├── photonOperatorMappings │ │ │ └── databricks-13_3.json │ │ ├── supportedDataSource.csv │ │ ├── supportedExecs.csv │ │ └── supportedExprs.csv │ └── scala │ │ ├── com │ │ └── nvidia │ │ │ └── spark │ │ │ └── rapids │ │ │ ├── SparkRapidsBuildInfoEvent.scala │ │ │ ├── ThreadFactoryBuilder.scala │ │ │ └── tool │ │ │ ├── AppSummaryInfoBaseProvider.scala │ │ │ ├── ClusterConfigurationStrategy.scala │ │ │ ├── EventLogPathProcessor.scala │ │ │ ├── GpuDevice.scala │ │ │ ├── Identifiable.scala │ │ │ ├── Platform.scala │ │ │ ├── ToolBase.scala │ │ │ ├── ToolTextFileWriter.scala │ │ │ ├── analysis │ │ │ ├── AggRawMetricsResult.scala │ │ │ ├── AppAnalysisBase.scala │ │ │ ├── AppIndexMapperTrait.scala │ │ │ ├── AppSQLPlanAnalyzer.scala │ │ │ ├── AppSparkMetricsAggTrait.scala │ │ │ ├── AppSparkMetricsAnalyzer.scala │ │ │ ├── ProfSparkMetricsAggregator.scala │ │ │ ├── QualSparkMetricsAggregator.scala │ │ │ ├── SparkSQLPlanInfoVisitor.scala │ │ │ ├── StatisticsMetrics.scala │ │ │ ├── package.scala │ │ │ └── util │ │ │ │ ├── AggAccumHelper.scala │ │ │ │ ├── AggAccumPhotonHelper.scala │ │ │ │ ├── DiagnosticMetrics.scala │ │ │ │ ├── JobAggAccum.scala │ │ │ │ ├── SQLAggAccum.scala │ │ │ │ ├── StageAggAccum.scala │ │ │ │ ├── StageAggPhoton.scala │ │ │ │ └── TaskMetricsAccumRec.scala │ │ │ ├── planparser │ │ │ ├── BaseSourceScanExecParser.scala │ │ │ ├── BatchScanExecParser.scala │ │ │ ├── BroadcastExchangeExecParser.scala │ │ │ ├── BroadcastHashJoinExecParser.scala │ │ │ ├── BroadcastNestedLoopJoinExecParser.scala │ │ │ ├── DataWritingCommandExecParser.scala │ │ │ ├── DatabricksParseHelper.scala │ │ │ ├── ExecParser.scala │ │ │ ├── FileSourceScanExecParser.scala │ │ │ ├── GenericExecParser.scala │ │ │ ├── GroupParserTrait.scala │ │ │ ├── HashAggregateExecParser.scala │ │ │ ├── HiveParseHelper.scala │ │ │ ├── ObjectHashAggregateExecParser.scala │ │ │ ├── ReadParser.scala │ │ │ ├── SQLPlanParser.scala │ │ │ ├── ShuffleExchangeExecParser.scala │ │ │ ├── ShuffledHashJoinExecParser.scala │ │ │ ├── SortMergeJoinExecParser.scala │ │ │ ├── SubqueryBroadcastExecParser.scala │ │ │ ├── SubqueryExecParser.scala │ │ │ ├── SupportedBlankExec.scala │ │ │ ├── SupportedOpStub.scala │ │ │ ├── WholeStageExecParser.scala │ │ │ ├── WindowGroupLimitParser.scala │ │ │ ├── WriteOpMetaExtractorTrait.scala │ │ │ ├── auron │ │ │ │ ├── AuronParseHelper.scala │ │ │ │ └── AuronPlugin.scala │ │ │ ├── delta │ │ │ │ ├── DeltaLakeBlankExec.scala │ │ │ │ ├── DeltaLakeHelper.scala │ │ │ │ ├── DeltaLakeOSSPlugin.scala │ │ │ │ └── DeltaLakeOps.scala │ │ │ ├── iceberg │ │ │ │ ├── AppendDataIcebergExtract.scala │ │ │ │ ├── AppendDataIcebergParser.scala │ │ │ │ ├── IcebergHelper.scala │ │ │ │ └── IcebergWriteOps.scala │ │ │ ├── ops │ │ │ │ ├── ExprOpRef.scala │ │ │ │ ├── OpRef.scala │ │ │ │ ├── OpRefWrapperBase.scala │ │ │ │ ├── OperatorCounter.scala │ │ │ │ ├── OperatorRefBase.scala │ │ │ │ ├── OperatorRefTrait.scala │ │ │ │ └── UnsupportedExprOpRef.scala │ │ │ └── photon │ │ │ │ ├── PhotonBroadcastNestedLoopJoinExecParser.scala │ │ │ │ ├── PhotonPlanParser.scala │ │ │ │ └── PhotonStageExecParser.scala │ │ │ ├── plugins │ │ │ ├── AppPropPlugContainerTrait.scala │ │ │ ├── AppPropPlugTrait.scala │ │ │ ├── AppPropVersionExtractorFromCPTrait.scala │ │ │ ├── AppPropVersionExtractorTrait.scala │ │ │ ├── BaseAppPropPlug.scala │ │ │ ├── PropConditionOnSparkExtTrait.scala │ │ │ └── PropConditionTrait.scala │ │ │ ├── profiling │ │ │ ├── ApplicationSummaryInfo.scala │ │ │ ├── CollectInformation.scala │ │ │ ├── DiagnosticSummaryInfo.scala │ │ │ ├── DriverLogProcessor.scala │ │ │ ├── GenerateDot.scala │ │ │ ├── GenerateTimeline.scala │ │ │ ├── HealthCheck.scala │ │ │ ├── ProfSQLPlanClassifier.scala │ │ │ ├── ProfileArgs.scala │ │ │ ├── ProfileClassWarehouse.scala │ │ │ ├── ProfileMain.scala │ │ │ ├── ProfileOutputWriter.scala │ │ │ ├── ProfileUtils.scala │ │ │ └── Profiler.scala │ │ │ ├── qualification │ │ │ ├── AppSubscriber.scala │ │ │ ├── PluginTypeChecker.scala │ │ │ ├── QualOutputWriter.scala │ │ │ ├── QualToolResult.scala │ │ │ ├── Qualification.scala │ │ │ ├── QualificationArgs.scala │ │ │ ├── QualificationMain.scala │ │ │ ├── RunningAppMetadata.scala │ │ │ ├── RunningQualOutputWriter.scala │ │ │ └── RunningQualificationApp.scala │ │ │ ├── tuning │ │ │ ├── AutoTuner.scala │ │ │ ├── AutoTunerReportGenerator.scala │ │ │ ├── QualAppSummaryInfoProvider.scala │ │ │ ├── QualificationAutoTuner.scala │ │ │ ├── QualificationAutoTunerRunner.scala │ │ │ ├── TargetClusterProps.scala │ │ │ ├── TunerContext.scala │ │ │ ├── TuningConfigsProvider.scala │ │ │ ├── TuningEntry.scala │ │ │ ├── TuningEntryDefinition.scala │ │ │ ├── TuningEntryTrait.scala │ │ │ └── TuningOpTypes.scala │ │ │ └── views │ │ │ ├── AggMetricsResultSorter.scala │ │ │ ├── AppStageMetricsView.scala │ │ │ ├── DataSourceView.scala │ │ │ ├── ExecutorView.scala │ │ │ ├── InformationView.scala │ │ │ ├── JobView.scala │ │ │ ├── OutHeaderRegistry.scala │ │ │ ├── PropertiesView.scala │ │ │ ├── QualRawReportGenerator.scala │ │ │ ├── RawMetricProfView.scala │ │ │ ├── SQLView.scala │ │ │ ├── StageView.scala │ │ │ ├── TaskView.scala │ │ │ ├── ViewableTrait.scala │ │ │ ├── WriteOpsView.scala │ │ │ ├── package.scala │ │ │ └── qualification │ │ │ ├── QualOutputTableDefinition.scala │ │ │ ├── QualPerAppReportGenerator.scala │ │ │ ├── QualReportGenConfProvider.scala │ │ │ ├── QualReportGeneratorTrait.scala │ │ │ ├── QualTableBuilderTrait.scala │ │ │ ├── QualToolReportGenerator.scala │ │ │ └── QualYamlConfigLoader.scala │ │ └── org │ │ └── apache │ │ └── spark │ │ ├── rapids │ │ └── tool │ │ │ └── benchmarks │ │ │ ├── Benchmark.scala │ │ │ ├── BenchmarkArgs.scala │ │ │ ├── BenchmarkBase.scala │ │ │ ├── DevRuntimeCheckpoint.scala │ │ │ ├── NoOpRuntimeCheckpoint.scala │ │ │ ├── README.md │ │ │ ├── RuntimeCheckpointTrait.scala │ │ │ ├── RuntimeInjector.scala │ │ │ ├── SingleThreadedProfileToolBenchmark.scala │ │ │ └── SingleThreadedQualToolBenchmark.scala │ │ ├── scheduler │ │ ├── SparkListenerEvent.scala │ │ └── ToolsListenerEventExtraAPIs.scala │ │ └── sql │ │ └── rapids │ │ └── tool │ │ ├── AccumToStageRetriever.scala │ │ ├── AppBase.scala │ │ ├── AppFilterImpl.scala │ │ ├── AppMetaData.scala │ │ ├── ClassWarehouse.scala │ │ ├── ClusterTagPropHandler.scala │ │ ├── EventLogParserTrait.scala │ │ ├── EventProcessorBase.scala │ │ ├── FilterAppInfo.scala │ │ ├── ToolUtils.scala │ │ ├── annotation │ │ ├── Calculated.scala │ │ ├── Since.scala │ │ ├── ToolsReflection.scala │ │ ├── WallClock.scala │ │ └── package.scala │ │ ├── profiling │ │ ├── ApplicationInfo.scala │ │ └── EventsProcessor.scala │ │ ├── qualification │ │ ├── QualAppMainSummary.scala │ │ ├── QualificationAppInfo.scala │ │ ├── QualificationEventProcessor.scala │ │ └── RunningQualificationEventProcessor.scala │ │ ├── store │ │ ├── AccumInfo.scala │ │ ├── AccumManager.scala │ │ ├── AccumMetaRef.scala │ │ ├── AccumNameRef.scala │ │ ├── DataSourceRecord.scala │ │ ├── SQLPlanModel.scala │ │ ├── SQLPlanModelManager.scala │ │ ├── SQLPlanModelPrimaryWithDSCaching.scala │ │ ├── SQLPlanModelWithDSCaching.scala │ │ ├── SQLPlanVersion.scala │ │ ├── StageModel.scala │ │ ├── StageModelManager.scala │ │ ├── TaskModel.scala │ │ ├── TaskModelManager.scala │ │ └── WriteOperationStore.scala │ │ ├── ui │ │ └── ConsoleProgressBar.scala │ │ └── util │ │ ├── CacheablePropsHandler.scala │ │ ├── EventLogReaderConf.scala │ │ ├── EventUtils.scala │ │ ├── FSUtils.scala │ │ ├── InPlaceMedianArrView.scala │ │ ├── MemoryMetricsTracker.scala │ │ ├── OperationResult.scala │ │ ├── PropertiesLoader.scala │ │ ├── RapidsToolsConfUtil.scala │ │ ├── RuntimeReporter.scala │ │ ├── RuntimeUtil.scala │ │ ├── SortedJProperties.scala │ │ ├── StringUtils.scala │ │ ├── ToolsMetric.scala │ │ ├── ToolsPlanGraph.scala │ │ ├── ToolsTimer.scala │ │ ├── WebCrawlerUtil.scala │ │ ├── package.scala │ │ ├── plangraph │ │ ├── PhotonPlan.scala │ │ └── PlanGraphTransformer.scala │ │ └── stubs │ │ ├── DefaultGraphReflectionAPI.scala │ │ ├── GraphReflectionAPI.scala │ │ ├── GraphReflectionAPIHelper.scala │ │ ├── GraphReflectionEntry.scala │ │ ├── StageInfoStub.scala │ │ ├── bd │ │ ├── BDGraphClusterStub.scala │ │ ├── BDGraphNodeStub.scala │ │ └── BDGraphReflectionAPI.scala │ │ ├── db │ │ ├── DBGraphClusterStub.scala │ │ ├── DBGraphEdgeStub.scala │ │ ├── DBGraphNodeStub.scala │ │ ├── DBGraphReflectionAPI.scala │ │ └── DBGraphSQLMetricStub.scala │ │ └── package.scala │ └── test │ ├── resources │ ├── ProfilingExpectations │ │ ├── executors_removed_eventlog_expectation.csv │ │ ├── jobs_failure_eventlog_expectation.csv │ │ ├── nds_q88_photon_db_13_3_job_metrics_agg_expectation.csv │ │ ├── nds_q88_photon_db_13_3_sql_metrics_agg_expectation.csv │ │ ├── nds_q88_photon_db_13_3_stage_metrics_agg_expectation.csv │ │ ├── rapids_duration_and_cpu_expectation.csv │ │ ├── rapids_join_eventlog_iodiagnosticmetrics_expectation.csv │ │ ├── rapids_join_eventlog_jobmetricsagg2_expectation.csv │ │ ├── rapids_join_eventlog_jobmetricsagg_expectation.csv │ │ ├── rapids_join_eventlog_sqlmetrics_expectation.csv │ │ ├── rapids_join_eventlog_sqlmetricsagg2_expectation.csv │ │ ├── rapids_join_eventlog_sqlmetricsagg_expectation.csv │ │ ├── rapids_join_eventlog_stagediagnosticmetrics_expectation.csv │ │ ├── rapids_join_eventlog_stagemetricsagg2_expectation.csv │ │ ├── rapids_join_eventlog_stagemetricsagg_expectation.csv │ │ ├── removed_blockManagers_eventlog_expectation.csv │ │ ├── stages_failure_eventlog_expectation.csv │ │ ├── tasks_failure_eventlog_expectation.csv │ │ └── unsupported_sql_eventlog_expectation.csv │ ├── QualificationExpectations │ │ ├── db_eventlog_rolling │ │ │ ├── apps_summary.csv │ │ │ └── local-1623876083964 │ │ │ │ └── persql.csv │ │ ├── dsv1_complex │ │ │ ├── apps_summary.csv │ │ │ └── local-1626104300434 │ │ │ │ └── persql.csv │ │ ├── empty_eventlog │ │ │ ├── apps_summary.csv │ │ │ └── local-1623263471760 │ │ │ │ └── persql.csv │ │ ├── eventlog_rolling │ │ │ ├── apps_summary.csv │ │ │ └── local-1623876083964 │ │ │ │ └── persql.csv │ │ ├── jdbc_eventlog │ │ │ ├── app-20211019113801-0001 │ │ │ │ └── persql.csv │ │ │ └── apps_summary.csv │ │ ├── missing_sql_end │ │ │ ├── apps_summary.csv │ │ │ └── local-1622561780883 │ │ │ │ └── persql.csv │ │ ├── nds_q86_fail_test │ │ │ ├── app-20210319163812-1778 │ │ │ │ └── persql.csv │ │ │ └── apps_summary.csv │ │ ├── nds_q86_test │ │ │ ├── app-20210319163812-1778 │ │ │ │ └── persql.csv │ │ │ └── apps_summary.csv │ │ ├── nested_dsv2 │ │ │ ├── apps_summary.csv │ │ │ └── local-1630045673160 │ │ │ │ └── persql.csv │ │ ├── nested_type_eventlog │ │ │ ├── apps_summary.csv │ │ │ └── local-1629446106683 │ │ │ │ └── persql.csv │ │ ├── photon_db_13_3 │ │ │ ├── app-20240919162642-0000 │ │ │ │ ├── execs.csv │ │ │ │ └── persql.csv │ │ │ └── apps_summary.csv │ │ ├── read_dsv2 │ │ │ ├── apps_summary.csv │ │ │ └── local-1624371906627 │ │ │ │ └── persql.csv │ │ ├── repeated_jobname │ │ │ ├── apps_summary.csv │ │ │ ├── local-1623263471760 │ │ │ │ └── persql.csv │ │ │ └── local-1629446106683 │ │ │ │ └── persql.csv │ │ ├── simple_udf │ │ │ ├── apps_summary.csv │ │ │ ├── local-1622043423018 │ │ │ │ └── persql.csv │ │ │ ├── local-1623281204390 │ │ │ │ └── persql.csv │ │ │ ├── local-1651187225439 │ │ │ │ └── persql.csv │ │ │ └── local-1651188809790 │ │ │ │ └── persql.csv │ │ ├── spark_2 │ │ │ └── apps_summary.csv │ │ ├── support_multiple_attempts │ │ │ ├── application_1724877841851_0016 │ │ │ │ └── persql.csv │ │ │ └── apps_summary.csv │ │ ├── truncated_1_end │ │ │ ├── apps_summary.csv │ │ │ └── local-1622043423018 │ │ │ │ └── persql.csv │ │ └── writeformat_eventlog │ │ │ ├── apps_summary.csv │ │ │ └── local-1629442299891 │ │ │ └── persql.csv │ ├── key-value-pairs.txt │ ├── log4j.properties │ ├── log4j2.properties │ ├── spark-events-profiling │ │ ├── dataset_eventlog │ │ ├── driverlog │ │ ├── eventlog-gpu-dsv1.zstd │ │ ├── eventlog-gpu-dsv2.zstd │ │ ├── eventlog_dsv1.zstd │ │ ├── eventlog_dsv2.zstd │ │ ├── eventlog_minimal_events │ │ ├── gds_ucx_eventlog.zstd │ │ ├── gpu_oom_eventlog.zstd │ │ ├── malformed_json_eventlog.zstd │ │ ├── nds_q66_gpu.zstd │ │ ├── rapids_join_eventlog.zstd │ │ ├── rapids_join_eventlog2.zstd │ │ ├── rp_nosql_eventlog │ │ ├── rp_sql_eventlog.zstd │ │ ├── spark2-eventlog.zstd │ │ └── tasks_executors_fail_compressed_eventlog.zstd │ └── spark-events-qualification │ │ ├── aqeshuffle_eventlog.zstd │ │ ├── cluster_information │ │ ├── eventlog_2nodes_8cores │ │ ├── eventlog_3nodes_12cores_exec_removed │ │ ├── eventlog_3nodes_12cores_multiple_executors │ │ ├── eventlog_3nodes_12cores_variable_cores │ │ ├── eventlog_4nodes_8cores_dynamic_alloc.zstd │ │ ├── eventlog_driver_only │ │ └── platform │ │ │ ├── databricks-aws │ │ │ ├── databricks-azure │ │ │ ├── dataproc │ │ │ ├── emr │ │ │ └── onprem │ │ ├── complex_dec_eventlog.zstd │ │ ├── createdatasourcetable_eventlog.zstd │ │ ├── customshuffle_eventlog.zstd │ │ ├── dataset_eventlog │ │ ├── db_sim_eventlog │ │ ├── eventlog │ │ └── eventlog-2021-06-15--15-00.gz │ │ ├── db_subExecution_id.zstd │ │ ├── dsAndDf_eventlog.zstd │ │ ├── empty_eventlog │ │ ├── eventlog_complex_dec_nested │ │ ├── eventlog_nested_dsv2 │ │ ├── eventlog_same_app_id_1.zstd │ │ ├── eventlog_same_app_id_2.zstd │ │ ├── eventlog_v2_local-1623876083964 │ │ ├── appstatus_local-1623876083964 │ │ ├── events_1_local-1623876083964.zstd │ │ └── events_2_local-1623876083964.zstd │ │ ├── global_local_limit_eventlog.zstd │ │ ├── gpu_eventlog │ │ ├── jdbc_eventlog.zstd │ │ ├── join_missing_sql_end │ │ ├── multiple_attempts │ │ ├── attempt_1_eventlog.zstd │ │ ├── attempt_2_eventlog.zstd │ │ ├── attempt_3_eventlog.zstd │ │ └── attempt_4_eventlog.zstd │ │ ├── nds_q72_dataproc_2_2.zstd │ │ ├── nds_q86_fail_test │ │ ├── nds_q86_test │ │ ├── nds_q88_photon_db_13_3.zstd │ │ ├── nested_type_eventlog │ │ ├── pandas_execs_eventlog.zstd │ │ ├── rdd_only_eventlog │ │ ├── truncated_eventlog │ │ ├── udf_dataset_eventlog │ │ ├── udf_func_eventlog │ │ ├── writeformat_eventlog │ │ └── xgboost_eventlog.zstd │ └── scala │ ├── com │ └── nvidia │ │ └── spark │ │ └── rapids │ │ ├── BaseNoSparkSuite.scala │ │ ├── BaseTestSuite.scala │ │ ├── BaseWithSparkSuite.scala │ │ ├── ThreadFactoryBuilderTest.scala │ │ └── tool │ │ ├── EventlogProviderImpl.scala │ │ ├── EventlogProviderTrait.scala │ │ ├── ToolTestUtils.scala │ │ ├── planparser │ │ ├── BasePlanParserSuite.scala │ │ ├── PhotonPlanParserSuite.scala │ │ ├── ReadParserSuite.scala │ │ ├── SqlPlanParserSuite.scala │ │ └── WriteOperationParserSuite.scala │ │ ├── profiling │ │ ├── AnalysisSuite.scala │ │ ├── AppFilterSuite.scala │ │ ├── ApplicationInfoSuite.scala │ │ ├── ClusterRecommendationSuite.scala │ │ ├── GenerateDotSuite.scala │ │ ├── GenerateTimelineSuite.scala │ │ ├── HealthCheckSuite.scala │ │ └── QualificationInfoUtils.scala │ │ ├── qualification │ │ ├── AppFilterSuite.scala │ │ ├── PluginTypeCheckerSuite.scala │ │ ├── QualificationNoSparkSuite.scala │ │ ├── QualificationSuite.scala │ │ ├── RunningQualificationSuite.scala │ │ └── checkers │ │ │ ├── QToolCSVFileContainer.scala │ │ │ ├── QToolOutFileChecker.scala │ │ │ ├── QToolOutJsonFileChecker.scala │ │ │ ├── QToolResultCheckerTrait.scala │ │ │ ├── QToolResultCoreChecker.scala │ │ │ ├── QToolStatusChecker.scala │ │ │ ├── QToolTestCtxt.scala │ │ │ └── QToolTestCtxtBuilder.scala │ │ ├── tuning │ │ ├── BaseAutoTunerSuite.scala │ │ ├── ProfilingAutoTunerSuite.scala │ │ ├── ProfilingAutoTunerSuiteV2.scala │ │ └── QualificationAutoTunerSuite.scala │ │ └── util │ │ └── ToolUtilsSuite.scala │ └── org │ └── apache │ └── spark │ └── sql │ └── TrampolineUtil.scala ├── scripts ├── auto-copyrighter.sh ├── header-check.sh ├── idea-code-style-settings.xml ├── prefetch_deps.sh ├── qual_validation │ └── qual_validation.py └── sync_plugin_files │ ├── README.md │ ├── override_supported_configs.json │ ├── process_supported_files.py │ └── sync_operator_scores.py └── user_tools ├── LICENSE ├── README.md ├── build.sh ├── docs ├── index.md ├── qualx.md ├── resources │ ├── debug-behave-intellij.png │ ├── spark_rapids_user_tools_overview-01.drawio │ └── spark_rapids_user_tools_overview-01.png ├── tools_e2e_tests.md ├── user-tools-aws-emr.md ├── user-tools-databricks-aws.md ├── user-tools-databricks-azure.md ├── user-tools-dataproc-gke.md ├── user-tools-dataproc.md ├── user-tools-onprem.md └── user-tools-reports-api.md ├── pyproject.toml ├── src ├── spark_rapids_pytools │ ├── __init__.py │ ├── build.py │ ├── cloud_api │ │ ├── __init__.py │ │ ├── azurestorage.py │ │ ├── databricks_aws.py │ │ ├── databricks_aws_job.py │ │ ├── databricks_azure.py │ │ ├── databricks_azure_job.py │ │ ├── dataproc.py │ │ ├── dataproc_gke.py │ │ ├── dataproc_gke_job.py │ │ ├── dataproc_job.py │ │ ├── emr.py │ │ ├── emr_job.py │ │ ├── gstorage.py │ │ ├── onprem.py │ │ ├── s3storage.py │ │ └── sp_types.py │ ├── common │ │ ├── __init__.py │ │ ├── cluster_inference.py │ │ ├── exceptions.py │ │ ├── prop_manager.py │ │ ├── sys_storage.py │ │ └── utilities.py │ ├── pricing │ │ ├── __init__.py │ │ ├── databricks_aws_pricing.py │ │ ├── databricks_azure_pricing.py │ │ ├── dataproc_gke_pricing.py │ │ ├── dataproc_pricing.py │ │ ├── emr_pricing.py │ │ └── price_provider.py │ ├── rapids │ │ ├── __init__.py │ │ ├── bootstrap.py │ │ ├── dev │ │ │ └── instance_description.py │ │ ├── diagnostic.py │ │ ├── profiling.py │ │ ├── profiling_core.py │ │ ├── qualification.py │ │ ├── qualification_core.py │ │ ├── qualification_stats.py │ │ ├── qualx │ │ │ ├── prediction.py │ │ │ ├── qualx_tool.py │ │ │ ├── train.py │ │ │ └── train_and_evaluate.py │ │ ├── rapids_job.py │ │ ├── rapids_tool.py │ │ └── tool_ctxt.py │ ├── resources │ │ ├── bootstrap-conf.yaml │ │ ├── cluster-configs.yaml │ │ ├── collect.sh │ │ ├── databricks_aws-configs.json │ │ ├── databricks_azure-configs.json │ │ ├── databricks_azure-instance-catalog.json │ │ ├── dataproc-configs.json │ │ ├── dataproc-instance-catalog.json │ │ ├── dataproc_gke-configs.json │ │ ├── dev │ │ │ ├── databricks-azure-price-jobs-compute-premium-westus2-raw.txt │ │ │ ├── log4j.properties │ │ │ ├── prepackage_mgr.py │ │ │ └── process_databricks_azure_pricing.py │ │ ├── diagnostic-conf.yaml │ │ ├── distributed-tools-conf.yaml │ │ ├── emr-configs.json │ │ ├── emr-instance-catalog.json │ │ ├── generated_files │ │ │ └── .gitkeep │ │ ├── onprem-configs.json │ │ ├── premium-databricks-azure-catalog.json │ │ ├── profiling-conf.yaml │ │ ├── qualification-conf.yaml │ │ ├── qualx-conf.yaml │ │ ├── qualx-hash-conf.yaml │ │ ├── qualx-pipeline-conf-example.yaml │ │ ├── qualx │ │ │ └── models │ │ │ │ └── xgboost │ │ │ │ ├── combined.cfg │ │ │ │ ├── combined.json │ │ │ │ ├── combined.metrics │ │ │ │ ├── databricks-aws.cfg │ │ │ │ ├── databricks-aws.json │ │ │ │ ├── databricks-aws.metrics │ │ │ │ ├── databricks-aws_photon.cfg │ │ │ │ ├── databricks-aws_photon.json │ │ │ │ ├── databricks-aws_photon.metrics │ │ │ │ ├── databricks-azure.cfg │ │ │ │ ├── databricks-azure.json │ │ │ │ ├── databricks-azure.metrics │ │ │ │ ├── databricks-azure_photon.cfg │ │ │ │ ├── databricks-azure_photon.json │ │ │ │ ├── databricks-azure_photon.metrics │ │ │ │ ├── dataproc.cfg │ │ │ │ ├── dataproc.json │ │ │ │ ├── dataproc.metrics │ │ │ │ ├── emr.cfg │ │ │ │ ├── emr.json │ │ │ │ ├── emr.metrics │ │ │ │ ├── onprem.cfg │ │ │ │ ├── onprem.json │ │ │ │ └── onprem.metrics │ │ ├── reports │ │ │ ├── profWrapperReport.yaml │ │ │ └── qualWrapperReport.yaml │ │ └── templates │ │ │ ├── cluster_template │ │ │ ├── databricks_aws.ms │ │ │ ├── databricks_azure.ms │ │ │ ├── dataproc.ms │ │ │ ├── emr.ms │ │ │ └── onprem.ms │ │ │ ├── dataproc-create_gpu_cluster_script.ms │ │ │ ├── dataproc-run_bootstrap.ms │ │ │ ├── emr-create_gpu_cluster_script.ms │ │ │ ├── emr-run_bootstrap.ms │ │ │ └── node_template │ │ │ ├── databricks_aws.ms │ │ │ ├── databricks_azure.ms │ │ │ └── emr.ms │ ├── wrapper.py │ └── wrappers │ │ ├── __init__.py │ │ ├── databricks_aws_wrapper.py │ │ ├── databricks_azure_wrapper.py │ │ ├── dataproc_wrapper.py │ │ └── emr_wrapper.py ├── spark_rapids_tools │ ├── __init__.py │ ├── api_v1 │ │ ├── __init__.py │ │ ├── app_handler.py │ │ ├── builder.py │ │ ├── common.py │ │ ├── core │ │ │ ├── __init__.py │ │ │ ├── core_reader.py │ │ │ ├── prof_handler.py │ │ │ ├── prof_reader.py │ │ │ ├── qual_handler.py │ │ │ └── qual_reader.py │ │ ├── report_loader.py │ │ ├── report_reader.py │ │ ├── result_handler.py │ │ ├── table_definition.py │ │ └── wrapper │ │ │ ├── __init__.py │ │ │ ├── prof_handler.py │ │ │ └── qual_handler.py │ ├── cloud │ │ ├── __init__.py │ │ ├── cluster.py │ │ ├── databricks │ │ │ ├── __init__.py │ │ │ └── dbcluster.py │ │ ├── dataproc │ │ │ ├── __init__.py │ │ │ └── dataproccluster.py │ │ ├── emr │ │ │ ├── __init__.py │ │ │ └── emrcluster.py │ │ └── onprem │ │ │ ├── __init__.py │ │ │ └── onpremcluster.py │ ├── cmdli │ │ ├── __init__.py │ │ ├── argprocessor.py │ │ ├── dev_cli.py │ │ └── tools_cli.py │ ├── configuration │ │ ├── __init__.py │ │ ├── common.py │ │ ├── runtime_conf.py │ │ ├── submission │ │ │ ├── __init__.py │ │ │ ├── distributed_config.py │ │ │ └── local_config.py │ │ └── tools_config.py │ ├── enums.py │ ├── exceptions.py │ ├── storagelib │ │ ├── __init__.py │ │ ├── adls │ │ │ ├── __init__.py │ │ │ ├── adlsfs.py │ │ │ └── adlspath.py │ │ ├── cspfs.py │ │ ├── csppath.py │ │ ├── gcs │ │ │ ├── __init__.py │ │ │ ├── gcsfs.py │ │ │ └── gcspath.py │ │ ├── hdfs │ │ │ ├── __init__.py │ │ │ ├── hdfsfs.py │ │ │ └── hdfspath.py │ │ ├── local │ │ │ ├── __init__.py │ │ │ ├── localfs.py │ │ │ └── localpath.py │ │ ├── s3 │ │ │ ├── __init__.py │ │ │ ├── s3fs.py │ │ │ └── s3path.py │ │ └── tools │ │ │ └── fs_utils.py │ ├── tools │ │ ├── __init__.py │ │ ├── additional_heuristics.py │ │ ├── cluster_config_recommender.py │ │ ├── qualification_stats_report.py │ │ ├── qualx │ │ │ ├── config.py │ │ │ ├── featurizers │ │ │ │ ├── default.py │ │ │ │ └── hash_plan.py │ │ │ ├── hash_config.py │ │ │ ├── hash_util.py │ │ │ ├── model.py │ │ │ ├── modifiers │ │ │ │ └── align_sql_id.py │ │ │ ├── plot.py │ │ │ ├── preprocess.py │ │ │ ├── qualx_config.py │ │ │ ├── qualx_main.py │ │ │ ├── qualx_pipeline.py │ │ │ ├── split_functions │ │ │ │ ├── split_all_test.py │ │ │ │ ├── split_random.py │ │ │ │ ├── split_stratified.py │ │ │ │ └── split_train_val.py │ │ │ └── util.py │ │ ├── speedup_category.py │ │ ├── top_candidates.py │ │ └── unsupported_ops_stage_duration.py │ └── utils │ │ ├── __init__.py │ │ ├── compat.py │ │ ├── data_utils.py │ │ ├── net_utils.py │ │ ├── propmanager.py │ │ └── util.py └── spark_rapids_tools_distributed │ ├── __init__.py │ ├── distributed_main.py │ ├── jar_cmd_args.py │ ├── output_processing │ ├── __init__.py │ ├── combiner.py │ └── processors.py │ ├── spark_management │ ├── __init__.py │ ├── spark_job_submitter.py │ └── spark_session_builder.py │ └── spark_map_task │ ├── __init__.py │ ├── jar_runner.py │ └── status_reporter.py ├── tests ├── __init__.py ├── mock_cluster.py ├── spark_rapids_tools_e2e │ ├── features │ │ ├── environment.py │ │ ├── event_log_processing.feature │ │ ├── hdfs_storage.feature │ │ ├── installation_checks.feature │ │ ├── preprocess.feature │ │ ├── result_handler.feature │ │ └── steps │ │ │ ├── e2e_utils.py │ │ │ ├── preprocess_steps.py │ │ │ ├── test_result_handler_steps.py │ │ │ └── test_steps.py │ └── resources │ │ ├── datasets │ │ └── onprem │ │ │ └── nds.json │ │ ├── event_logs │ │ ├── gpu_eventlog.zstd │ │ ├── incorrect_app_status_eventlog.zstd │ │ ├── join_agg_on_yarn_eventlog.zstd │ │ ├── onprem │ │ │ ├── README.md │ │ │ └── nds │ │ │ │ └── power │ │ │ │ └── eventlogs │ │ │ │ ├── cpu │ │ │ │ └── app-20231122005806-0064.zstd │ │ │ │ └── gpu │ │ │ │ └── app-20231114200842-0001.zstd │ │ ├── photon_eventlog.zstd │ │ └── streaming_eventlog.zstd │ │ ├── scripts │ │ ├── common.sh │ │ └── hdfs │ │ │ ├── cleanup_hdfs.sh │ │ │ ├── setup_hdfs.sh │ │ │ └── templates │ │ │ ├── core-site.xml │ │ │ └── hdfs-site.xml │ │ └── target_cluster_files │ │ ├── target-cluster-only-spark-props.yaml │ │ └── target-cluster-worker-info-and-spark-props.yaml ├── spark_rapids_tools_ut │ ├── __init__.py │ ├── api │ │ ├── __init__.py │ │ ├── test_api_base.py │ │ ├── test_app_handlers.py │ │ └── test_tuning_reports.py │ ├── conftest.py │ ├── qualx │ │ ├── __init__.py │ │ ├── test_config.py │ │ ├── test_hash_util.py │ │ ├── test_main.py │ │ ├── test_model.py │ │ ├── test_modifiers.py │ │ ├── test_preprocess.py │ │ ├── test_qualx_config.py │ │ ├── test_split_functions.py │ │ └── test_utils.py │ ├── resources │ │ ├── cluster │ │ │ ├── databricks │ │ │ │ ├── aws-cpu-00.json │ │ │ │ ├── azure-cpu-00.json │ │ │ │ └── test-azure-instances-catalog.json │ │ │ ├── dataproc │ │ │ │ └── cpu-00.yaml │ │ │ ├── dataproc_gke │ │ │ │ └── cpu-00.yaml │ │ │ ├── emr │ │ │ │ └── cpu-00.json │ │ │ └── onprem │ │ │ │ └── cpu-00.yaml │ │ ├── eventlogs │ │ │ └── .gitkeep │ │ ├── tools_config │ │ │ ├── invalid │ │ │ │ ├── tools_config_inv_00.yaml │ │ │ │ ├── tools_config_inv_01.yaml │ │ │ │ └── tools_config_inv_02.yaml │ │ │ ├── sample-distributed-config-specification.json │ │ │ ├── sample-local-config-specification.json │ │ │ └── valid │ │ │ │ ├── tools_config_00.yaml │ │ │ │ ├── tools_config_01.yaml │ │ │ │ ├── tools_config_02.yaml │ │ │ │ └── tools_config_03.yaml │ │ ├── tools_mock.jar │ │ └── worker_info.yaml │ ├── test_cluster.py │ └── test_tool_argprocessor.py ├── test_diagnostic.py └── utils │ ├── test_data_utils.py │ └── test_net_utils.py └── tox.ini /.github/ISSUE_TEMPLATE/bug_report.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/ISSUE_TEMPLATE/bug_report.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/documentation-request.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/ISSUE_TEMPLATE/documentation-request.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/feature_request.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/ISSUE_TEMPLATE/feature_request.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/submit-question.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/ISSUE_TEMPLATE/submit-question.md -------------------------------------------------------------------------------- /.github/PULL_REQUEST_TEMPLATE.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/PULL_REQUEST_TEMPLATE.md -------------------------------------------------------------------------------- /.github/labeler.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/labeler.yml -------------------------------------------------------------------------------- /.github/workflows/add-to-project.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/add-to-project.yml -------------------------------------------------------------------------------- /.github/workflows/configuration.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/configuration.json -------------------------------------------------------------------------------- /.github/workflows/labeler.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/labeler.yml -------------------------------------------------------------------------------- /.github/workflows/license-header-check.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/license-header-check.yml -------------------------------------------------------------------------------- /.github/workflows/markdown-links-check.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/markdown-links-check.yml -------------------------------------------------------------------------------- /.github/workflows/markdown-links-check/markdown-links-check-config.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/markdown-links-check/markdown-links-check-config.json -------------------------------------------------------------------------------- /.github/workflows/mvn-verify-check.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/mvn-verify-check.yml -------------------------------------------------------------------------------- /.github/workflows/python-unit-test.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/python-unit-test.yml -------------------------------------------------------------------------------- /.github/workflows/release.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/release.yml -------------------------------------------------------------------------------- /.github/workflows/shell-check.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/shell-check.yml -------------------------------------------------------------------------------- /.github/workflows/signoff-check.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.github/workflows/signoff-check.yml -------------------------------------------------------------------------------- /.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.gitignore -------------------------------------------------------------------------------- /.pre-commit-config.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.pre-commit-config.yaml -------------------------------------------------------------------------------- /.pylintrc: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/.pylintrc -------------------------------------------------------------------------------- /CHANGELOG.md: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /CONTRIBUTING.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/CONTRIBUTING.md -------------------------------------------------------------------------------- /LICENSE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/LICENSE -------------------------------------------------------------------------------- /NOTICE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/NOTICE -------------------------------------------------------------------------------- /NOTICE-binary: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/NOTICE-binary -------------------------------------------------------------------------------- /README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/README.md -------------------------------------------------------------------------------- /SECURITY.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/SECURITY.md -------------------------------------------------------------------------------- /core/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/.gitignore -------------------------------------------------------------------------------- /core/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/README.md -------------------------------------------------------------------------------- /core/docs/qual_core_output.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/qual_core_output.md -------------------------------------------------------------------------------- /core/docs/sampleFiles/bootstrap/customTuningConfigs.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/bootstrap/customTuningConfigs.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster01.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster01.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster02.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster02.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster03.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster03.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster04.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster04.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster05.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster05.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster06.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster06.yaml -------------------------------------------------------------------------------- /core/docs/sampleFiles/targetClusterInfo/targetCluster07.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/docs/sampleFiles/targetClusterInfo/targetCluster07.yaml -------------------------------------------------------------------------------- /core/pom.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/pom.xml -------------------------------------------------------------------------------- /core/scalastyle-config.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/scalastyle-config.xml -------------------------------------------------------------------------------- /core/src/main/resources/bootstrap/tuningConfigs.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/bootstrap/tuningConfigs.yaml -------------------------------------------------------------------------------- /core/src/main/resources/bootstrap/tuningTable.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/bootstrap/tuningTable.yaml -------------------------------------------------------------------------------- /core/src/main/resources/configs/build.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/configs/build.properties -------------------------------------------------------------------------------- /core/src/main/resources/configs/reports/coreRawMetricsReport.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/configs/reports/coreRawMetricsReport.yaml -------------------------------------------------------------------------------- /core/src/main/resources/configs/reports/profCoreReport.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/configs/reports/profCoreReport.yaml -------------------------------------------------------------------------------- /core/src/main/resources/configs/reports/qualCoreReport.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/configs/reports/qualCoreReport.yaml -------------------------------------------------------------------------------- /core/src/main/resources/configs/reports/qualOutputTable.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/configs/reports/qualOutputTable.yaml -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-databricks-aws-a10G.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-databricks-aws-a10G.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-databricks-aws-t4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-databricks-aws-t4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-databricks-azure-t4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-databricks-azure-t4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-dataproc-gke-l4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-dataproc-gke-l4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-dataproc-gke-t4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-dataproc-gke-t4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-dataproc-l4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-dataproc-l4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-dataproc-serverless-l4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-dataproc-serverless-l4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-dataproc-t4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-dataproc-t4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-emr-a10.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-emr-a10.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-emr-a10G.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-emr-a10G.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-emr-t4.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-emr-t4.csv -------------------------------------------------------------------------------- /core/src/main/resources/operatorsScore-onprem-a100.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/operatorsScore-onprem-a100.csv -------------------------------------------------------------------------------- /core/src/main/resources/parser/eventlog-parser.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/parser/eventlog-parser.yaml -------------------------------------------------------------------------------- /core/src/main/resources/photonOperatorMappings/databricks-13_3.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/photonOperatorMappings/databricks-13_3.json -------------------------------------------------------------------------------- /core/src/main/resources/supportedDataSource.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/supportedDataSource.csv -------------------------------------------------------------------------------- /core/src/main/resources/supportedExecs.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/supportedExecs.csv -------------------------------------------------------------------------------- /core/src/main/resources/supportedExprs.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/resources/supportedExprs.csv -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/SparkRapidsBuildInfoEvent.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/SparkRapidsBuildInfoEvent.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/ThreadFactoryBuilder.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/ThreadFactoryBuilder.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/AppSummaryInfoBaseProvider.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/AppSummaryInfoBaseProvider.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/ClusterConfigurationStrategy.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/ClusterConfigurationStrategy.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/EventLogPathProcessor.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/EventLogPathProcessor.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/GpuDevice.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/GpuDevice.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/Identifiable.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/Identifiable.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/Platform.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/Platform.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/ToolBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/ToolBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/ToolTextFileWriter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/ToolTextFileWriter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AggRawMetricsResult.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AggRawMetricsResult.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppAnalysisBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppAnalysisBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppIndexMapperTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppIndexMapperTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSQLPlanAnalyzer.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSQLPlanAnalyzer.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSparkMetricsAggTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSparkMetricsAggTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSparkMetricsAnalyzer.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/AppSparkMetricsAnalyzer.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/ProfSparkMetricsAggregator.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/ProfSparkMetricsAggregator.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/QualSparkMetricsAggregator.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/QualSparkMetricsAggregator.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/SparkSQLPlanInfoVisitor.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/SparkSQLPlanInfoVisitor.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/StatisticsMetrics.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/StatisticsMetrics.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/package.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/package.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/AggAccumHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/AggAccumHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/AggAccumPhotonHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/AggAccumPhotonHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/DiagnosticMetrics.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/DiagnosticMetrics.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/JobAggAccum.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/JobAggAccum.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/SQLAggAccum.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/SQLAggAccum.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/StageAggAccum.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/StageAggAccum.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/StageAggPhoton.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/StageAggPhoton.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/TaskMetricsAccumRec.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/analysis/util/TaskMetricsAccumRec.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BaseSourceScanExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BaseSourceScanExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BatchScanExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BatchScanExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BroadcastExchangeExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BroadcastExchangeExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BroadcastHashJoinExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/BroadcastHashJoinExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/DatabricksParseHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/DatabricksParseHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/FileSourceScanExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/FileSourceScanExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/GenericExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/GenericExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/GroupParserTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/GroupParserTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/HashAggregateExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/HashAggregateExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/HiveParseHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/HiveParseHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ReadParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ReadParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SQLPlanParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SQLPlanParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ShuffleExchangeExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ShuffleExchangeExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ShuffledHashJoinExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ShuffledHashJoinExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SortMergeJoinExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SortMergeJoinExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SubqueryBroadcastExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SubqueryBroadcastExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SubqueryExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SubqueryExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SupportedBlankExec.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SupportedBlankExec.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SupportedOpStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/SupportedOpStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WholeStageExecParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WholeStageExecParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WindowGroupLimitParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WindowGroupLimitParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WriteOpMetaExtractorTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/WriteOpMetaExtractorTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/auron/AuronParseHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/auron/AuronParseHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/auron/AuronPlugin.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/auron/AuronPlugin.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeBlankExec.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeBlankExec.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeOSSPlugin.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeOSSPlugin.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeOps.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/delta/DeltaLakeOps.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/iceberg/IcebergHelper.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/iceberg/IcebergHelper.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/iceberg/IcebergWriteOps.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/iceberg/IcebergWriteOps.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/ExprOpRef.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/ExprOpRef.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OpRef.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OpRef.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OpRefWrapperBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OpRefWrapperBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorCounter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorCounter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorRefBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorRefBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorRefTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/OperatorRefTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/UnsupportedExprOpRef.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/ops/UnsupportedExprOpRef.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/photon/PhotonPlanParser.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/planparser/photon/PhotonPlanParser.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropPlugContainerTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropPlugContainerTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropPlugTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropPlugTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropVersionExtractorTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/AppPropVersionExtractorTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/BaseAppPropPlug.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/BaseAppPropPlug.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/PropConditionOnSparkExtTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/PropConditionOnSparkExtTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/PropConditionTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/plugins/PropConditionTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ApplicationSummaryInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ApplicationSummaryInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/CollectInformation.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/CollectInformation.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/DiagnosticSummaryInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/DiagnosticSummaryInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/DriverLogProcessor.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/DriverLogProcessor.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/GenerateDot.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/GenerateDot.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/GenerateTimeline.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/GenerateTimeline.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/HealthCheck.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/HealthCheck.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfSQLPlanClassifier.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfSQLPlanClassifier.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileArgs.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileArgs.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileClassWarehouse.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileClassWarehouse.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileMain.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileMain.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileOutputWriter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileOutputWriter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/ProfileUtils.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/Profiler.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/profiling/Profiler.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/AppSubscriber.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/AppSubscriber.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/PluginTypeChecker.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/PluginTypeChecker.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualOutputWriter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualOutputWriter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualToolResult.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualToolResult.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/Qualification.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/Qualification.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualificationArgs.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualificationArgs.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualificationMain.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/QualificationMain.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningAppMetadata.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningAppMetadata.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningQualOutputWriter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningQualOutputWriter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningQualificationApp.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/qualification/RunningQualificationApp.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/AutoTuner.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/AutoTuner.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/AutoTunerReportGenerator.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/AutoTunerReportGenerator.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualAppSummaryInfoProvider.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualAppSummaryInfoProvider.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTuner.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTuner.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTunerRunner.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTunerRunner.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TargetClusterProps.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TargetClusterProps.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TunerContext.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TunerContext.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningConfigsProvider.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningConfigsProvider.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntry.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntry.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntryDefinition.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntryDefinition.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntryTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningEntryTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningOpTypes.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/tuning/TuningOpTypes.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/AggMetricsResultSorter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/AggMetricsResultSorter.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/AppStageMetricsView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/AppStageMetricsView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/DataSourceView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/DataSourceView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/ExecutorView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/ExecutorView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/InformationView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/InformationView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/JobView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/JobView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/OutHeaderRegistry.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/OutHeaderRegistry.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/PropertiesView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/PropertiesView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/QualRawReportGenerator.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/QualRawReportGenerator.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/RawMetricProfView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/RawMetricProfView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/SQLView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/SQLView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/StageView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/StageView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/TaskView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/TaskView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/ViewableTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/ViewableTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/WriteOpsView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/WriteOpsView.scala -------------------------------------------------------------------------------- /core/src/main/scala/com/nvidia/spark/rapids/tool/views/package.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/com/nvidia/spark/rapids/tool/views/package.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/Benchmark.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/Benchmark.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/BenchmarkArgs.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/BenchmarkArgs.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/BenchmarkBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/BenchmarkBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/DevRuntimeCheckpoint.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/DevRuntimeCheckpoint.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/NoOpRuntimeCheckpoint.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/NoOpRuntimeCheckpoint.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/README.md -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/RuntimeCheckpointTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/RuntimeCheckpointTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/RuntimeInjector.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/rapids/tool/benchmarks/RuntimeInjector.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/scheduler/SparkListenerEvent.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/scheduler/SparkListenerEvent.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/scheduler/ToolsListenerEventExtraAPIs.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/scheduler/ToolsListenerEventExtraAPIs.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/AccumToStageRetriever.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/AccumToStageRetriever.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/AppBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/AppBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/AppFilterImpl.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/AppFilterImpl.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/AppMetaData.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/AppMetaData.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/ClassWarehouse.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/ClassWarehouse.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/ClusterTagPropHandler.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/ClusterTagPropHandler.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/EventLogParserTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/EventLogParserTrait.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/EventProcessorBase.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/EventProcessorBase.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/FilterAppInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/FilterAppInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/ToolUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/ToolUtils.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/Calculated.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/Calculated.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/Since.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/Since.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/ToolsReflection.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/ToolsReflection.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/WallClock.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/WallClock.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/package.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/annotation/package.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/profiling/ApplicationInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/profiling/ApplicationInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/profiling/EventsProcessor.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/profiling/EventsProcessor.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/qualification/QualAppMainSummary.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/qualification/QualAppMainSummary.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/qualification/QualificationAppInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/qualification/QualificationAppInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumInfo.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumInfo.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumManager.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumManager.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumMetaRef.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumMetaRef.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumNameRef.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/AccumNameRef.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/DataSourceRecord.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/DataSourceRecord.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModel.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModel.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModelManager.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModelManager.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModelWithDSCaching.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanModelWithDSCaching.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanVersion.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/SQLPlanVersion.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/StageModel.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/StageModel.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/StageModelManager.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/StageModelManager.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/TaskModel.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/TaskModel.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/TaskModelManager.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/TaskModelManager.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/store/WriteOperationStore.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/store/WriteOperationStore.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/ui/ConsoleProgressBar.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/ui/ConsoleProgressBar.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/CacheablePropsHandler.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/CacheablePropsHandler.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/EventLogReaderConf.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/EventLogReaderConf.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/EventUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/EventUtils.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/FSUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/FSUtils.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/InPlaceMedianArrView.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/InPlaceMedianArrView.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/MemoryMetricsTracker.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/MemoryMetricsTracker.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/OperationResult.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/OperationResult.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/PropertiesLoader.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/PropertiesLoader.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RapidsToolsConfUtil.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RapidsToolsConfUtil.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RuntimeReporter.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RuntimeReporter.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RuntimeUtil.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/RuntimeUtil.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/SortedJProperties.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/SortedJProperties.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/StringUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/StringUtils.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsMetric.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsMetric.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsPlanGraph.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsPlanGraph.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsTimer.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/ToolsTimer.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/WebCrawlerUtil.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/WebCrawlerUtil.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/package.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/package.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/plangraph/PhotonPlan.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/plangraph/PhotonPlan.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/GraphReflectionAPI.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/GraphReflectionAPI.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/GraphReflectionEntry.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/GraphReflectionEntry.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/StageInfoStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/StageInfoStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphClusterStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphClusterStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphNodeStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphNodeStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphReflectionAPI.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/bd/BDGraphReflectionAPI.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphClusterStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphClusterStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphEdgeStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphEdgeStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphNodeStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphNodeStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphReflectionAPI.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphReflectionAPI.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphSQLMetricStub.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/db/DBGraphSQLMetricStub.scala -------------------------------------------------------------------------------- /core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/package.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/main/scala/org/apache/spark/sql/rapids/tool/util/stubs/package.scala -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/executors_removed_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/executors_removed_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/jobs_failure_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/jobs_failure_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/rapids_duration_and_cpu_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/rapids_duration_and_cpu_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/rapids_join_eventlog_sqlmetrics_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/rapids_join_eventlog_sqlmetrics_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/removed_blockManagers_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/removed_blockManagers_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/stages_failure_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/stages_failure_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/tasks_failure_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/tasks_failure_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/ProfilingExpectations/unsupported_sql_eventlog_expectation.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/ProfilingExpectations/unsupported_sql_eventlog_expectation.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/db_eventlog_rolling/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/db_eventlog_rolling/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/dsv1_complex/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/dsv1_complex/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/dsv1_complex/local-1626104300434/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/dsv1_complex/local-1626104300434/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/empty_eventlog/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/empty_eventlog/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/eventlog_rolling/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/eventlog_rolling/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/jdbc_eventlog/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/jdbc_eventlog/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/missing_sql_end/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/missing_sql_end/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/nds_q86_fail_test/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/nds_q86_fail_test/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/nds_q86_test/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/nds_q86_test/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/nested_dsv2/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/nested_dsv2/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/nested_dsv2/local-1630045673160/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/nested_dsv2/local-1630045673160/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/nested_type_eventlog/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/nested_type_eventlog/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/photon_db_13_3/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/photon_db_13_3/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/read_dsv2/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/read_dsv2/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/read_dsv2/local-1624371906627/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/read_dsv2/local-1624371906627/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/repeated_jobname/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/repeated_jobname/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/simple_udf/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/simple_udf/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/simple_udf/local-1622043423018/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/simple_udf/local-1622043423018/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/simple_udf/local-1623281204390/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/simple_udf/local-1623281204390/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/simple_udf/local-1651187225439/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/simple_udf/local-1651187225439/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/simple_udf/local-1651188809790/persql.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/simple_udf/local-1651188809790/persql.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/spark_2/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/spark_2/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/truncated_1_end/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/truncated_1_end/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/QualificationExpectations/writeformat_eventlog/apps_summary.csv: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/QualificationExpectations/writeformat_eventlog/apps_summary.csv -------------------------------------------------------------------------------- /core/src/test/resources/key-value-pairs.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/key-value-pairs.txt -------------------------------------------------------------------------------- /core/src/test/resources/log4j.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/log4j.properties -------------------------------------------------------------------------------- /core/src/test/resources/log4j2.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/log4j2.properties -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/dataset_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/dataset_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/driverlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/driverlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/eventlog-gpu-dsv1.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/eventlog-gpu-dsv1.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/eventlog-gpu-dsv2.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/eventlog-gpu-dsv2.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/eventlog_dsv1.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/eventlog_dsv1.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/eventlog_dsv2.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/eventlog_dsv2.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/eventlog_minimal_events: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/eventlog_minimal_events -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/gds_ucx_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/gds_ucx_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/gpu_oom_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/gpu_oom_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/malformed_json_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/malformed_json_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/nds_q66_gpu.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/nds_q66_gpu.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/rapids_join_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/rapids_join_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/rapids_join_eventlog2.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/rapids_join_eventlog2.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/rp_nosql_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/rp_nosql_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/rp_sql_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/rp_sql_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-profiling/spark2-eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-profiling/spark2-eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/aqeshuffle_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/aqeshuffle_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/cluster_information/eventlog_driver_only: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/cluster_information/eventlog_driver_only -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/cluster_information/platform/dataproc: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/cluster_information/platform/dataproc -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/cluster_information/platform/emr: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/cluster_information/platform/emr -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/cluster_information/platform/onprem: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/cluster_information/platform/onprem -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/complex_dec_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/complex_dec_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/createdatasourcetable_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/createdatasourcetable_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/customshuffle_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/customshuffle_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/dataset_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/dataset_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/db_sim_eventlog/eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/db_sim_eventlog/eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/db_subExecution_id.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/db_subExecution_id.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/dsAndDf_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/dsAndDf_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/empty_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/empty_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/eventlog_complex_dec_nested: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/eventlog_complex_dec_nested -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/eventlog_nested_dsv2: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/eventlog_nested_dsv2 -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/eventlog_same_app_id_1.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/eventlog_same_app_id_1.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/eventlog_same_app_id_2.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/eventlog_same_app_id_2.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/eventlog_v2_local-1623876083964/appstatus_local-1623876083964: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/global_local_limit_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/global_local_limit_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/gpu_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/gpu_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/jdbc_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/jdbc_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/join_missing_sql_end: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/join_missing_sql_end -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/nds_q72_dataproc_2_2.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/nds_q72_dataproc_2_2.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/nds_q86_fail_test: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/nds_q86_fail_test -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/nds_q86_test: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/nds_q86_test -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/nds_q88_photon_db_13_3.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/nds_q88_photon_db_13_3.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/nested_type_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/nested_type_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/pandas_execs_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/pandas_execs_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/rdd_only_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/rdd_only_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/truncated_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/truncated_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/udf_dataset_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/udf_dataset_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/udf_func_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/udf_func_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/writeformat_eventlog: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/writeformat_eventlog -------------------------------------------------------------------------------- /core/src/test/resources/spark-events-qualification/xgboost_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/resources/spark-events-qualification/xgboost_eventlog.zstd -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/BaseNoSparkSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/BaseNoSparkSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/BaseTestSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/BaseTestSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/BaseWithSparkSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/BaseWithSparkSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/ThreadFactoryBuilderTest.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/ThreadFactoryBuilderTest.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/EventlogProviderImpl.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/EventlogProviderImpl.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/EventlogProviderTrait.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/EventlogProviderTrait.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/ToolTestUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/ToolTestUtils.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/BasePlanParserSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/BasePlanParserSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/PhotonPlanParserSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/PhotonPlanParserSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/ReadParserSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/ReadParserSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/SqlPlanParserSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/SqlPlanParserSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/WriteOperationParserSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/planparser/WriteOperationParserSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/AnalysisSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/AnalysisSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/AppFilterSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/AppFilterSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/ApplicationInfoSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/ApplicationInfoSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/ClusterRecommendationSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/ClusterRecommendationSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/GenerateDotSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/GenerateDotSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/GenerateTimelineSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/GenerateTimelineSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/HealthCheckSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/HealthCheckSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/QualificationInfoUtils.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/profiling/QualificationInfoUtils.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/AppFilterSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/AppFilterSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/PluginTypeCheckerSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/PluginTypeCheckerSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/QualificationSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/QualificationSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/checkers/QToolTestCtxt.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/qualification/checkers/QToolTestCtxt.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/BaseAutoTunerSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/BaseAutoTunerSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/ProfilingAutoTunerSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/ProfilingAutoTunerSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/ProfilingAutoTunerSuiteV2.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/ProfilingAutoTunerSuiteV2.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTunerSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/tuning/QualificationAutoTunerSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/com/nvidia/spark/rapids/tool/util/ToolUtilsSuite.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/com/nvidia/spark/rapids/tool/util/ToolUtilsSuite.scala -------------------------------------------------------------------------------- /core/src/test/scala/org/apache/spark/sql/TrampolineUtil.scala: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/core/src/test/scala/org/apache/spark/sql/TrampolineUtil.scala -------------------------------------------------------------------------------- /scripts/auto-copyrighter.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/auto-copyrighter.sh -------------------------------------------------------------------------------- /scripts/header-check.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/header-check.sh -------------------------------------------------------------------------------- /scripts/idea-code-style-settings.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/idea-code-style-settings.xml -------------------------------------------------------------------------------- /scripts/prefetch_deps.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/prefetch_deps.sh -------------------------------------------------------------------------------- /scripts/qual_validation/qual_validation.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/qual_validation/qual_validation.py -------------------------------------------------------------------------------- /scripts/sync_plugin_files/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/sync_plugin_files/README.md -------------------------------------------------------------------------------- /scripts/sync_plugin_files/override_supported_configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/sync_plugin_files/override_supported_configs.json -------------------------------------------------------------------------------- /scripts/sync_plugin_files/process_supported_files.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/sync_plugin_files/process_supported_files.py -------------------------------------------------------------------------------- /scripts/sync_plugin_files/sync_operator_scores.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/scripts/sync_plugin_files/sync_operator_scores.py -------------------------------------------------------------------------------- /user_tools/LICENSE: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/LICENSE -------------------------------------------------------------------------------- /user_tools/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/README.md -------------------------------------------------------------------------------- /user_tools/build.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/build.sh -------------------------------------------------------------------------------- /user_tools/docs/index.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/index.md -------------------------------------------------------------------------------- /user_tools/docs/qualx.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/qualx.md -------------------------------------------------------------------------------- /user_tools/docs/resources/debug-behave-intellij.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/resources/debug-behave-intellij.png -------------------------------------------------------------------------------- /user_tools/docs/resources/spark_rapids_user_tools_overview-01.drawio: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/resources/spark_rapids_user_tools_overview-01.drawio -------------------------------------------------------------------------------- /user_tools/docs/resources/spark_rapids_user_tools_overview-01.png: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/resources/spark_rapids_user_tools_overview-01.png -------------------------------------------------------------------------------- /user_tools/docs/tools_e2e_tests.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/tools_e2e_tests.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-aws-emr.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-aws-emr.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-databricks-aws.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-databricks-aws.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-databricks-azure.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-databricks-azure.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-dataproc-gke.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-dataproc-gke.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-dataproc.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-dataproc.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-onprem.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-onprem.md -------------------------------------------------------------------------------- /user_tools/docs/user-tools-reports-api.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/docs/user-tools-reports-api.md -------------------------------------------------------------------------------- /user_tools/pyproject.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/pyproject.toml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/build.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/build.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/azurestorage.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/azurestorage.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/databricks_aws.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/databricks_aws.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/databricks_aws_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/databricks_aws_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/databricks_azure.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/databricks_azure.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/databricks_azure_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/databricks_azure_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/dataproc.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/dataproc.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/dataproc_gke.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/dataproc_gke.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/dataproc_gke_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/dataproc_gke_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/dataproc_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/dataproc_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/emr.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/emr.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/emr_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/emr_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/gstorage.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/gstorage.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/onprem.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/onprem.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/s3storage.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/s3storage.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/cloud_api/sp_types.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/cloud_api/sp_types.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/cluster_inference.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/cluster_inference.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/exceptions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/exceptions.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/prop_manager.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/prop_manager.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/sys_storage.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/sys_storage.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/common/utilities.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/common/utilities.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/databricks_aws_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/databricks_aws_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/databricks_azure_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/databricks_azure_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/dataproc_gke_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/dataproc_gke_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/dataproc_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/dataproc_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/emr_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/emr_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/pricing/price_provider.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/pricing/price_provider.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/bootstrap.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/bootstrap.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/dev/instance_description.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/dev/instance_description.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/diagnostic.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/diagnostic.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/profiling.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/profiling.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/profiling_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/profiling_core.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualification.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualification.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualification_core.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualification_core.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualification_stats.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualification_stats.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualx/prediction.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualx/prediction.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualx/qualx_tool.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualx/qualx_tool.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualx/train.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualx/train.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/qualx/train_and_evaluate.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/qualx/train_and_evaluate.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/rapids_job.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/rapids_job.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/rapids_tool.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/rapids_tool.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/rapids/tool_ctxt.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/rapids/tool_ctxt.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/bootstrap-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/bootstrap-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/cluster-configs.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/cluster-configs.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/collect.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/collect.sh -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/databricks_aws-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/databricks_aws-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/databricks_azure-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/databricks_azure-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/databricks_azure-instance-catalog.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/databricks_azure-instance-catalog.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dataproc-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dataproc-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dataproc-instance-catalog.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dataproc-instance-catalog.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dataproc_gke-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dataproc_gke-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dev/log4j.properties: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dev/log4j.properties -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dev/prepackage_mgr.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dev/prepackage_mgr.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/dev/process_databricks_azure_pricing.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/dev/process_databricks_azure_pricing.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/diagnostic-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/diagnostic-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/distributed-tools-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/distributed-tools-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/emr-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/emr-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/emr-instance-catalog.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/emr-instance-catalog.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/generated_files/.gitkeep: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/onprem-configs.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/onprem-configs.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/premium-databricks-azure-catalog.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/premium-databricks-azure-catalog.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/profiling-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/profiling-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualification-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualification-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx-hash-conf.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx-hash-conf.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx-pipeline-conf-example.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx-pipeline-conf-example.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/combined.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-aws.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/databricks-azure.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/dataproc.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/emr.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.cfg: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.cfg -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.json -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.metrics: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/qualx/models/xgboost/onprem.metrics -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/reports/profWrapperReport.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/reports/profWrapperReport.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/reports/qualWrapperReport.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/reports/qualWrapperReport.yaml -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/databricks_aws.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/databricks_aws.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/dataproc.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/dataproc.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/emr.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/emr.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/onprem.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/cluster_template/onprem.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/dataproc-run_bootstrap.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/dataproc-run_bootstrap.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/emr-create_gpu_cluster_script.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/emr-create_gpu_cluster_script.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/emr-run_bootstrap.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/emr-run_bootstrap.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/node_template/databricks_aws.ms: -------------------------------------------------------------------------------- 1 | { 2 | "node_id" : "123456789qwertyuiop" 3 | } 4 | -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/node_template/databricks_azure.ms: -------------------------------------------------------------------------------- 1 | { 2 | "node_id" : "123456789qwertyuiop" 3 | } 4 | -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/resources/templates/node_template/emr.ms: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/resources/templates/node_template/emr.ms -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrapper.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrapper.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrappers/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrappers/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrappers/databricks_aws_wrapper.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrappers/databricks_aws_wrapper.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrappers/databricks_azure_wrapper.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrappers/databricks_azure_wrapper.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrappers/dataproc_wrapper.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrappers/dataproc_wrapper.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_pytools/wrappers/emr_wrapper.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_pytools/wrappers/emr_wrapper.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/app_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/app_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/builder.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/builder.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/common.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/common.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/core_reader.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/core_reader.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/prof_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/prof_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/prof_reader.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/prof_reader.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/qual_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/qual_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/core/qual_reader.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/core/qual_reader.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/report_loader.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/report_loader.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/report_reader.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/report_reader.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/result_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/result_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/table_definition.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/table_definition.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/wrapper/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/wrapper/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/wrapper/prof_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/wrapper/prof_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/api_v1/wrapper/qual_handler.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/api_v1/wrapper/qual_handler.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/cluster.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/databricks/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/databricks/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/databricks/dbcluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/databricks/dbcluster.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/dataproc/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/dataproc/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/dataproc/dataproccluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/dataproc/dataproccluster.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/emr/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/emr/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/emr/emrcluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/emr/emrcluster.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/onprem/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/onprem/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cloud/onprem/onpremcluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cloud/onprem/onpremcluster.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cmdli/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cmdli/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cmdli/argprocessor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cmdli/argprocessor.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cmdli/dev_cli.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cmdli/dev_cli.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/cmdli/tools_cli.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/cmdli/tools_cli.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/common.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/common.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/runtime_conf.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/runtime_conf.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/submission/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/submission/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/submission/distributed_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/submission/distributed_config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/submission/local_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/submission/local_config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/configuration/tools_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/configuration/tools_config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/enums.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/enums.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/exceptions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/exceptions.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/adls/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/adls/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/adls/adlsfs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/adls/adlsfs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/adls/adlspath.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/adls/adlspath.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/cspfs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/cspfs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/csppath.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/csppath.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/gcs/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/gcs/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/gcs/gcsfs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/gcs/gcsfs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/gcs/gcspath.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/gcs/gcspath.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/hdfs/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/hdfs/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/hdfs/hdfsfs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/hdfs/hdfsfs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/hdfs/hdfspath.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/hdfs/hdfspath.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/local/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/local/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/local/localfs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/local/localfs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/local/localpath.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/local/localpath.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/s3/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/s3/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/s3/s3fs.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/s3/s3fs.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/s3/s3path.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/s3/s3path.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/storagelib/tools/fs_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/storagelib/tools/fs_utils.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/additional_heuristics.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/additional_heuristics.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/cluster_config_recommender.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/cluster_config_recommender.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualification_stats_report.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualification_stats_report.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/featurizers/default.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/featurizers/default.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/featurizers/hash_plan.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/featurizers/hash_plan.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/hash_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/hash_config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/hash_util.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/hash_util.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/model.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/model.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/modifiers/align_sql_id.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/modifiers/align_sql_id.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/plot.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/plot.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/preprocess.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/preprocess.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/qualx_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/qualx_config.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/qualx_main.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/qualx_main.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/qualx_pipeline.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/qualx_pipeline.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_all_test.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_all_test.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_random.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_random.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_stratified.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_stratified.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_train_val.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/split_functions/split_train_val.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/qualx/util.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/qualx/util.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/speedup_category.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/speedup_category.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/top_candidates.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/top_candidates.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/tools/unsupported_ops_stage_duration.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/tools/unsupported_ops_stage_duration.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/compat.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/compat.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/data_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/data_utils.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/net_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/net_utils.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/propmanager.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/propmanager.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools/utils/util.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools/utils/util.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/distributed_main.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/distributed_main.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/jar_cmd_args.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/jar_cmd_args.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/output_processing/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/output_processing/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/output_processing/combiner.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/output_processing/combiner.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/output_processing/processors.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/output_processing/processors.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_management/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_management/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_management/spark_job_submitter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_management/spark_job_submitter.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_management/spark_session_builder.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_management/spark_session_builder.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_map_task/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_map_task/__init__.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_map_task/jar_runner.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_map_task/jar_runner.py -------------------------------------------------------------------------------- /user_tools/src/spark_rapids_tools_distributed/spark_map_task/status_reporter.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/src/spark_rapids_tools_distributed/spark_map_task/status_reporter.py -------------------------------------------------------------------------------- /user_tools/tests/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/__init__.py -------------------------------------------------------------------------------- /user_tools/tests/mock_cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/mock_cluster.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/environment.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/environment.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/event_log_processing.feature: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/event_log_processing.feature -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/hdfs_storage.feature: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/hdfs_storage.feature -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/installation_checks.feature: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/installation_checks.feature -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/preprocess.feature: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/preprocess.feature -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/result_handler.feature: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/result_handler.feature -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/steps/e2e_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/steps/e2e_utils.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/steps/preprocess_steps.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/steps/preprocess_steps.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/steps/test_result_handler_steps.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/steps/test_result_handler_steps.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/features/steps/test_steps.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/features/steps/test_steps.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/datasets/onprem/nds.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/datasets/onprem/nds.json -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/gpu_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/gpu_eventlog.zstd -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/join_agg_on_yarn_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/join_agg_on_yarn_eventlog.zstd -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/onprem/README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/onprem/README.md -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/photon_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/photon_eventlog.zstd -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/streaming_eventlog.zstd: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/event_logs/streaming_eventlog.zstd -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/scripts/common.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/scripts/common.sh -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/cleanup_hdfs.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/cleanup_hdfs.sh -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/setup_hdfs.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/setup_hdfs.sh -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/templates/core-site.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/templates/core-site.xml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/templates/hdfs-site.xml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_e2e/resources/scripts/hdfs/templates/hdfs-site.xml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/__init__.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/api/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/api/__init__.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/api/test_api_base.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/api/test_api_base.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/api/test_app_handlers.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/api/test_app_handlers.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/api/test_tuning_reports.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/api/test_tuning_reports.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/conftest.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/conftest.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/__init__.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/__init__.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_config.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_hash_util.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_hash_util.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_main.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_main.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_model.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_model.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_modifiers.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_modifiers.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_preprocess.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_preprocess.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_qualx_config.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_qualx_config.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_split_functions.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_split_functions.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/qualx/test_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/qualx/test_utils.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/databricks/aws-cpu-00.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/databricks/aws-cpu-00.json -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/databricks/azure-cpu-00.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/databricks/azure-cpu-00.json -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/dataproc/cpu-00.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/dataproc/cpu-00.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/dataproc_gke/cpu-00.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/dataproc_gke/cpu-00.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/emr/cpu-00.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/emr/cpu-00.json -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/cluster/onprem/cpu-00.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/cluster/onprem/cpu-00.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/eventlogs/.gitkeep: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_00.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_00.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_01.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_01.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_02.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_02.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_03.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/tools_config/valid/tools_config_03.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/tools_mock.jar: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/resources/worker_info.yaml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/resources/worker_info.yaml -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/test_cluster.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/test_cluster.py -------------------------------------------------------------------------------- /user_tools/tests/spark_rapids_tools_ut/test_tool_argprocessor.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/spark_rapids_tools_ut/test_tool_argprocessor.py -------------------------------------------------------------------------------- /user_tools/tests/test_diagnostic.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/test_diagnostic.py -------------------------------------------------------------------------------- /user_tools/tests/utils/test_data_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/utils/test_data_utils.py -------------------------------------------------------------------------------- /user_tools/tests/utils/test_net_utils.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tests/utils/test_net_utils.py -------------------------------------------------------------------------------- /user_tools/tox.ini: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/NVIDIA/spark-rapids-tools/HEAD/user_tools/tox.ini --------------------------------------------------------------------------------