Class

org.apache.spark.network.yarn

YarnShuffleService

Related Doc: package yarn

Permalink

class YarnShuffleService extends AuxiliaryService

Linear Supertypes
AuxiliaryService, AbstractService, Service, Closeable, AutoCloseable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. YarnShuffleService
  2. AuxiliaryService
  3. AbstractService
  4. Service
  5. Closeable
  6. AutoCloseable
  7. AnyRef
  8. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new YarnShuffleService()

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. final def close(): Unit

    Permalink
    Definition Classes
    AbstractService → Service → Closeable → AutoCloseable
    Annotations
    @throws( classOf[java.io.IOException] )
  7. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  8. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  9. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  10. def getAuxiliaryLocalPathHandler(): AuxiliaryLocalPathHandler

    Permalink
    Definition Classes
    AuxiliaryService
  11. def getBlockers(): Map[String, String]

    Permalink
    Definition Classes
    AbstractService → Service
  12. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  13. def getConfig(): Configuration

    Permalink
    Definition Classes
    AbstractService → Service
  14. final def getFailureCause(): Throwable

    Permalink
    Definition Classes
    AbstractService → Service
  15. def getFailureState(): STATE

    Permalink
    Definition Classes
    AbstractService → Service
  16. def getLifecycleHistory(): List[LifecycleEvent]

    Permalink
    Definition Classes
    AbstractService → Service
  17. def getMetaData(): ByteBuffer

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  18. def getName(): String

    Permalink
    Definition Classes
    AbstractService → Service
  19. def getRecoveryPath(fileName: String): Path

    Permalink
    Attributes
    protected[org.apache.spark.network.yarn]
  20. def getRecoveryPath(): Path

    Permalink
    Attributes
    protected[org.apache.hadoop.yarn.server.api]
    Definition Classes
    AuxiliaryService
  21. final def getServiceState(): STATE

    Permalink
    Definition Classes
    AbstractService → Service
  22. def getStartTime(): Long

    Permalink
    Definition Classes
    AbstractService → Service
  23. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  24. def init(arg0: Configuration): Unit

    Permalink
    Definition Classes
    AbstractService → Service
  25. def initRecoveryDb(dbFileName: String): File

    Permalink
    Attributes
    protected[org.apache.spark.network.yarn]
  26. def initializeApplication(context: ApplicationInitializationContext): Unit

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  27. def initializeContainer(context: ContainerInitializationContext): Unit

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  28. final def isInState(arg0: STATE): Boolean

    Permalink
    Definition Classes
    AbstractService → Service
  29. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  30. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  31. final def noteFailure(arg0: Exception): Unit

    Permalink
    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
  32. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  33. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  34. def putBlocker(arg0: String, arg1: String): Unit

    Permalink
    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
  35. def registerServiceListener(arg0: ServiceStateChangeListener): Unit

    Permalink
    Definition Classes
    AbstractService → Service
  36. def removeBlocker(arg0: String): Unit

    Permalink
    Definition Classes
    AbstractService
  37. def serviceInit(conf: Configuration): Unit

    Permalink
    Attributes
    protected[org.apache.spark.network.yarn]
    Definition Classes
    YarnShuffleService → AbstractService
  38. def serviceStart(): Unit

    Permalink
    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
    Annotations
    @throws( classOf[java.lang.Exception] )
  39. def serviceStop(): Unit

    Permalink
    Attributes
    protected[org.apache.spark.network.yarn]
    Definition Classes
    YarnShuffleService → AbstractService
  40. def setAuxiliaryLocalPathHandler(arg0: AuxiliaryLocalPathHandler): Unit

    Permalink
    Definition Classes
    AuxiliaryService
  41. def setConfig(arg0: Configuration): Unit

    Permalink
    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
  42. def setRecoveryPath(recoveryPath: Path): Unit

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  43. def start(): Unit

    Permalink
    Definition Classes
    AbstractService → Service
  44. def stop(): Unit

    Permalink
    Definition Classes
    AbstractService → Service
  45. def stopApplication(context: ApplicationTerminationContext): Unit

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  46. def stopContainer(context: ContainerTerminationContext): Unit

    Permalink
    Definition Classes
    YarnShuffleService → AuxiliaryService
  47. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  48. def toString(): String

    Permalink
    Definition Classes
    AbstractService → AnyRef → Any
  49. def unregisterServiceListener(arg0: ServiceStateChangeListener): Unit

    Permalink
    Definition Classes
    AbstractService → Service
  50. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  51. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  52. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  53. final def waitForServiceToStop(arg0: Long): Boolean

    Permalink
    Definition Classes
    AbstractService → Service

Inherited from AuxiliaryService

Inherited from AbstractService

Inherited from Service

Inherited from Closeable

Inherited from AutoCloseable

Inherited from AnyRef

Inherited from Any

Ungrouped