org.apache.spark.deploy.yarn

Client

class Client extends YarnClientImpl with Logging

The entry point (starting in Client#main() and Client#run()) for launching Spark on YARN. The Client submits an application to the global ResourceManager to launch Spark's ApplicationMaster, which will launch a Spark master process and negotiate resources throughout its duration.

Linear Supertypes
Logging, YarnClientImpl, YarnClient, AbstractService, Service, Closeable, AutoCloseable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. Client
  2. Logging
  3. YarnClientImpl
  4. YarnClient
  5. AbstractService
  6. Service
  7. Closeable
  8. AutoCloseable
  9. AnyRef
  10. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new Client(args: ClientArguments)

  2. new Client(args: ClientArguments, sparkConf: SparkConf)

  3. new Client(args: ClientArguments, conf: Configuration, sparkConf: SparkConf)

Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

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

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. val APP_FILE_PERMISSION: FsPermission

  7. val STAGING_DIR_PERMISSION: FsPermission

  8. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  9. def clone(): AnyRef

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

    Definition Classes
    AbstractService → Service → Closeable → AutoCloseable
    Annotations
    @throws( classOf[java.io.IOException] )
  11. def createApplication(): YarnClientApplication

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  12. def createContainerLaunchContext(newApp: GetNewApplicationResponse, localResources: HashMap[String, LocalResource], env: HashMap[String, String]): ContainerLaunchContext

  13. val credentials: Credentials

  14. final def eq(arg0: AnyRef): Boolean

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

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

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  17. def getAMRMToken(arg0: ApplicationId): Token[AMRMTokenIdentifier]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  18. def getAllQueues(): List[QueueInfo]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  19. def getAppStagingDir(appId: ApplicationId): String

  20. def getApplicationReport(arg0: ApplicationId): ApplicationReport

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  21. def getApplications(arg0: Set[String], arg1: EnumSet[YarnApplicationState]): List[ApplicationReport]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  22. def getApplications(arg0: EnumSet[YarnApplicationState]): List[ApplicationReport]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  23. def getApplications(arg0: Set[String]): List[ApplicationReport]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  24. def getApplications(): List[ApplicationReport]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  25. def getBlockers(): Map[String, String]

    Definition Classes
    AbstractService → Service
  26. def getChildQueueInfos(arg0: String): List[QueueInfo]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  27. final def getClass(): Class[_]

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

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

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

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

    Definition Classes
    AbstractService → Service
  32. def getName(): String

    Definition Classes
    AbstractService → Service
  33. def getNodeReports(arg0: <repeated...>[NodeState]): List[NodeReport]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  34. def getQueueAclsInfo(): List[QueueUserACLInfo]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  35. def getQueueInfo(arg0: String): QueueInfo

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  36. def getRMDelegationToken(arg0: Text): Token

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  37. def getRootQueueInfos(): List[QueueInfo]

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  38. final def getServiceState(): STATE

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

    Definition Classes
    AbstractService → Service
  40. def getYarnClusterMetrics(): YarnClusterMetrics

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  41. def hashCode(): Int

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

    Definition Classes
    AbstractService → Service
  43. final def isInState(arg0: STATE): Boolean

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

    Definition Classes
    Any
  45. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  46. def killApplication(arg0: ApplicationId): Unit

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  47. def log: Logger

    Attributes
    protected
    Definition Classes
    Logging
  48. def logClusterResourceDetails(): Unit

  49. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  50. def logDebug(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  51. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  52. def logError(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  53. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  54. def logInfo(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  55. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  56. def logTrace(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  57. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  58. def logWarning(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  59. def monitorApplication(appId: ApplicationId): Boolean

  60. final def ne(arg0: AnyRef): Boolean

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

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

    Definition Classes
    AnyRef
  63. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  64. def prepareLocalResources(appStagingDir: String): HashMap[String, LocalResource]

  65. def putBlocker(arg0: String, arg1: String): Unit

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

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

    Definition Classes
    AbstractService
  68. var rpc: YarnRPC

  69. def run(): Unit

  70. def runApp(): ApplicationId

  71. def serviceInit(arg0: Configuration): Unit

    Attributes
    protected[org.apache.hadoop.yarn.client.api.impl]
    Definition Classes
    YarnClientImpl → AbstractService
    Annotations
    @throws( classOf[java.lang.Exception] )
  72. def serviceStart(): Unit

    Attributes
    protected[org.apache.hadoop.yarn.client.api.impl]
    Definition Classes
    YarnClientImpl → AbstractService
    Annotations
    @throws( classOf[java.lang.Exception] )
  73. def serviceStop(): Unit

    Attributes
    protected[org.apache.hadoop.yarn.client.api.impl]
    Definition Classes
    YarnClientImpl → AbstractService
    Annotations
    @throws( classOf[java.lang.Exception] )
  74. def setConfig(arg0: Configuration): Unit

    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
  75. def setRMClient(arg0: ApplicationClientProtocol): Unit

    Definition Classes
    YarnClientImpl
  76. def setupLaunchEnv(localResources: HashMap[String, LocalResource], stagingDir: String): HashMap[String, String]

  77. def start(): Unit

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

    Definition Classes
    AbstractService → Service
  79. def submitApp(appContext: ApplicationSubmissionContext): ApplicationId

  80. def submitApplication(arg0: ApplicationSubmissionContext): ApplicationId

    Definition Classes
    YarnClientImpl → YarnClient
    Annotations
    @throws( classOf[java.io.IOException] ) @throws( ... )
  81. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  82. def toString(): String

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

    Definition Classes
    AbstractService → Service
  84. def userArgsToString(clientArgs: ClientArguments): String

  85. def validateArgs(): Unit

  86. def verifyClusterResources(app: GetNewApplicationResponse): Unit

  87. final def wait(): Unit

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

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

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

    Definition Classes
    AbstractService → Service
  91. val yarnConf: YarnConfiguration

Inherited from Logging

Inherited from YarnClientImpl

Inherited from YarnClient

Inherited from AbstractService

Inherited from Service

Inherited from Closeable

Inherited from AutoCloseable

Inherited from AnyRef

Inherited from Any

Ungrouped