Skip to content

Commit

Permalink
[SPARK-46596][CORE][TESTS] Correct package name of SslTestUtils
Browse files Browse the repository at this point in the history
### What changes were proposed in this pull request?
The package name for `SslTestUtils` is defined as `org.apache.spark`, but it is in the `org/apache/spark/util/` directory. This pr corrects its package name to ensure consistency.

### Why are the changes needed?
Correct package name of `SslTestUtils`

### Does this PR introduce _any_ user-facing change?
No

### How was this patch tested?
Pass GitHub Actions

### Was this patch authored or co-authored using generative AI tooling?
No

Closes #44596 from LuciferYang/SslTestUtils-package-name.

Lead-authored-by: yangjie01 <yangjie01@baidu.com>
Co-authored-by: YangJie <yangjie01@baidu.com>
Signed-off-by: Max Gekk <max.gekk@gmail.com>
  • Loading branch information
LuciferYang authored and MaxGekk committed Jan 4, 2024
1 parent 760de23 commit ddcfe6b
Show file tree
Hide file tree
Showing 9 changed files with 14 additions and 9 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -22,6 +22,7 @@ import org.apache.spark.internal.config
import org.apache.spark.network.TransportContext
import org.apache.spark.network.netty.SparkTransportConf
import org.apache.spark.network.shuffle.ExternalBlockHandler
import org.apache.spark.util.SslTestUtils

/**
* This suite creates an external shuffle server and routes all shuffle fetches through it.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,6 +17,8 @@

package org.apache.spark

import org.apache.spark.util.SslTestUtils

class SslShuffleNettySuite extends ShuffleNettySuite {

override def beforeAll(): Unit = {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -45,7 +45,7 @@ import org.apache.spark.rpc.RpcEnv
import org.apache.spark.scheduler.{SparkListener, SparkListenerExecutorAdded, SparkListenerExecutorRemoved, TaskDescription}
import org.apache.spark.scheduler.cluster.CoarseGrainedClusterMessages.{KillTask, LaunchTask}
import org.apache.spark.serializer.JavaSerializer
import org.apache.spark.util.{SerializableBuffer, ThreadUtils, Utils}
import org.apache.spark.util.{SerializableBuffer, SslTestUtils, ThreadUtils, Utils}

class CoarseGrainedExecutorBackendSuite extends SparkFunSuite
with LocalSparkContext with MockitoSugar {
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,15 +32,15 @@ import org.scalatest.matchers.must.Matchers
import org.scalatest.matchers.should.Matchers._
import org.scalatestplus.mockito.MockitoSugar

import org.apache.spark.{SecurityManager, SparkConf, SparkFunSuite, SslTestUtils}
import org.apache.spark.{SecurityManager, SparkConf, SparkFunSuite}
import org.apache.spark.internal.config._
import org.apache.spark.internal.config.Network
import org.apache.spark.network.{BlockDataManager, BlockTransferService}
import org.apache.spark.network.buffer.{ManagedBuffer, NioManagedBuffer}
import org.apache.spark.network.shuffle.BlockFetchingListener
import org.apache.spark.serializer.{JavaSerializer, SerializerManager}
import org.apache.spark.storage.{BlockId, ShuffleBlockId}
import org.apache.spark.util.ThreadUtils
import org.apache.spark.util.{SslTestUtils, ThreadUtils}

class NettyBlockTransferSecuritySuite extends SparkFunSuite with MockitoSugar with Matchers {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ import org.scalatestplus.mockito.MockitoSugar
import org.apache.spark._
import org.apache.spark.network.client.TransportClient
import org.apache.spark.rpc._
import org.apache.spark.util.ThreadUtils
import org.apache.spark.util.{SslTestUtils, ThreadUtils}

class NettyRpcEnvSuite extends RpcEnvSuite with MockitoSugar with TimeLimits {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -41,7 +41,7 @@ import org.apache.spark.network.util.TransportConf
import org.apache.spark.serializer.JavaSerializer
import org.apache.spark.shuffle.ShuffleBlockPusher.PushRequest
import org.apache.spark.storage._
import org.apache.spark.util.ThreadUtils
import org.apache.spark.util.{SslTestUtils, ThreadUtils}

class ShuffleBlockPusherSuite extends SparkFunSuite {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,11 +26,11 @@ import org.mockito.Mockito._
import org.mockito.invocation.InvocationOnMock
import org.roaringbitmap.RoaringBitmap

import org.apache.spark.{SparkConf, SparkFunSuite, SslTestUtils}
import org.apache.spark.{SparkConf, SparkFunSuite}
import org.apache.spark.internal.config
import org.apache.spark.shuffle.{IndexShuffleBlockResolver, ShuffleBlockInfo}
import org.apache.spark.storage._
import org.apache.spark.util.Utils
import org.apache.spark.util.{SslTestUtils, Utils}

class IndexShuffleBlockResolverSuite extends SparkFunSuite {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,8 @@

package org.apache.spark.storage

import org.apache.spark.{SparkConf, SslTestUtils}
import org.apache.spark.SparkConf
import org.apache.spark.util.SslTestUtils

class SslBlockManagerReplicationSuite extends BlockManagerReplicationSuite {
override def createConf(): SparkConf = {
Expand Down
3 changes: 2 additions & 1 deletion core/src/test/scala/org/apache/spark/util/SslTestUtils.scala
Original file line number Diff line number Diff line change
Expand Up @@ -15,8 +15,9 @@
* limitations under the License.
*/

package org.apache.spark
package org.apache.spark.util

import org.apache.spark.SparkConf
import org.apache.spark.network.ssl.SslSampleConfigs

object SslTestUtils {
Expand Down

0 comments on commit ddcfe6b

Please sign in to comment.