Skip to content

Commit b3e3211

Browse files
committed
resolve conflict
1 parent 0e589ec commit b3e3211

File tree

2 files changed

+5
-1
lines changed

2 files changed

+5
-1
lines changed

core/src/main/scala/org/apache/spark/SparkContext.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -41,7 +41,7 @@ import org.apache.hadoop.mapreduce.lib.input.{FileInputFormat => NewFileInputFor
4141

4242
import org.apache.spark.annotation.DeveloperApi
4343
import org.apache.spark.broadcast.Broadcast
44-
import org.apache.spark.deploy.{LocalSparkCluster, SparkHadoopUtil, SparkSubmitUtils}
44+
import org.apache.spark.deploy.{LocalSparkCluster, SparkHadoopUtil}
4545
import org.apache.spark.executor.{Executor, ExecutorMetrics, ExecutorMetricsSource}
4646
import org.apache.spark.input.{FixedLengthBinaryInputFormat, PortableDataStream, StreamInputFormat, WholeTextFileInputFormat}
4747
import org.apache.spark.internal.Logging

core/src/main/scala/org/apache/spark/util/Utils.scala

Lines changed: 4 additions & 0 deletions
Original file line numberDiff line numberDiff line change
@@ -3046,6 +3046,10 @@ private[spark] object Utils extends Logging {
30463046
} else {
30473047
transitive.last._2.toBoolean
30483048
}
3049+
}
3050+
}
3051+
3052+
/**
30493053
* Convert MEMORY_OFFHEAP_SIZE to MB Unit, return 0 if MEMORY_OFFHEAP_ENABLED is false.
30503054
*/
30513055
def executorOffHeapMemorySizeAsMb(sparkConf: SparkConf): Int = {

0 commit comments

Comments
 (0)