Details

    Description

      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/deploy/client/StandaloneAppClient.scala:93:11: reference to stop is ambiguous;
      [error] it is both defined in the enclosing class StandaloneAppClient and inherited in the enclosing class ClientEndpoint as method stop (defined in trait RpcEndpoint, inherited through parent trait ThreadSafeRpcEndpoint)
      [error] In Scala 2, symbols inherited from a superclass shadow symbols defined in an outer scope.
      [error] Such references are ambiguous in Scala 3. To continue using the inherited symbol, write `this.stop`.
      [error] Or use `-Wconf:msg=legacy-binding:s` to silence this warning. [quickfixable]
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=other, site=org.apache.spark.deploy.client.StandaloneAppClient.ClientEndpoint.onStart
      [error]           stop()
      [error]           ^
      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/deploy/client/StandaloneAppClient.scala:171:9: reference to stop is ambiguous;
      [error] it is both defined in the enclosing class StandaloneAppClient and inherited in the enclosing class ClientEndpoint as method stop (defined in trait RpcEndpoint, inherited through parent trait ThreadSafeRpcEndpoint)
      [error] In Scala 2, symbols inherited from a superclass shadow symbols defined in an outer scope.
      [error] Such references are ambiguous in Scala 3. To continue using the inherited symbol, write `this.stop`.
      [error] Or use `-Wconf:msg=legacy-binding:s` to silence this warning. [quickfixable]
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=other, site=org.apache.spark.deploy.client.StandaloneAppClient.ClientEndpoint.receive
      [error]         stop()
      [error]         ^
      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/deploy/client/StandaloneAppClient.scala:206:9: reference to stop is ambiguous;
      [error] it is both defined in the enclosing class StandaloneAppClient and inherited in the enclosing class ClientEndpoint as method stop (defined in trait RpcEndpoint, inherited through parent trait ThreadSafeRpcEndpoint)
      [error] In Scala 2, symbols inherited from a superclass shadow symbols defined in an outer scope.
      [error] Such references are ambiguous in Scala 3. To continue using the inherited symbol, write `this.stop`.
      [error] Or use `-Wconf:msg=legacy-binding:s` to silence this warning. [quickfixable]
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=other, site=org.apache.spark.deploy.client.StandaloneAppClient.ClientEndpoint.receiveAndReply
      [error]         stop()
      [error]         ^
      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/rdd/OrderedRDDFunctions.scala:100:21: the type test for pattern org.apache.spark.RangePartitioner[K,V] cannot be checked at runtime because it has type parameters eliminated by erasure
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=unchecked, site=org.apache.spark.rdd.OrderedRDDFunctions.filterByRange.rddToFilter
      [error]       case Some(rp: RangePartitioner[K, V]) =>
      [error]                     ^
      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/scheduler/cluster/CoarseGrainedSchedulerBackend.scala:322:9: reference to stop is ambiguous;
      [error] it is both defined in the enclosing class CoarseGrainedSchedulerBackend and inherited in the enclosing class DriverEndpoint as method stop (defined in trait RpcEndpoint, inherited through parent trait IsolatedThreadSafeRpcEndpoint)
      [error] In Scala 2, symbols inherited from a superclass shadow symbols defined in an outer scope.
      [error] Such references are ambiguous in Scala 3. To continue using the inherited symbol, write `this.stop`.
      [error] Or use `-Wconf:msg=legacy-binding:s` to silence this warning. [quickfixable]
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=other, site=org.apache.spark.scheduler.cluster.CoarseGrainedSchedulerBackend.DriverEndpoint.receiveAndReply
      [error]         stop()
      [error]         ^
      [info] compiling 29 Scala sources and 267 Java sources to /Users/yangjie01/SourceCode/git/spark-mine-sbt/connector/connect/common/target/scala-2.13/classes ...
      [warn] -target is deprecated: Use -release instead to compile against the correct platform API.
      [warn] Applicable -Wconf / @nowarn filters for this warning: msg=<part of the message>, cat=deprecation
      [error] /Users/yangjie01/SourceCode/git/spark-mine-sbt/core/src/main/scala/org/apache/spark/storage/DiskBlockObjectWriter.scala:66:7: reference to flush is ambiguous;
      [error] it is both defined in the enclosing class DiskBlockObjectWriter and inherited in the enclosing trait ManualCloseOutputStream as method flush (defined in class OutputStream)
      [error] In Scala 2, symbols inherited from a superclass shadow symbols defined in an outer scope.
      [error] Such references are ambiguous in Scala 3. To continue using the inherited symbol, write `this.flush`.
      [error] Or use `-Wconf:msg=legacy-binding:s` to silence this warning. [quickfixable]
      [error] Applicable -Wconf / @nowarn filters for this fatal warning: msg=<part of the message>, cat=other, site=org.apache.spark.storage.DiskBlockObjectWriter.ManualCloseOutputStream.close
      [error]       flush()
      [error]       ^ 

      Attachments

        Issue Links

          Activity

            People

              panbingkun BingKun Pan
              LuciferYang Yang Jie
              Votes:
              0 Vote for this issue
              Watchers:
              3 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: