org.apache.spark.deploy.yarn

Client

class Client extends YarnClientImpl with ClientBase with Logging

Version of org.apache.spark.deploy.yarn.ClientBase tailored to YARN's stable API.

Linear Supertypes
ClientBase, Logging, YarnClientImpl, YarnClient, AbstractService, Service, Closeable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. Client
  2. ClientBase
  3. Logging
  4. YarnClientImpl
  5. YarnClient
  6. AbstractService
  7. Service
  8. Closeable
  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(clientArgs: ClientArguments)

  2. new Client(clientArgs: ClientArguments, spConf: SparkConf)

  3. new Client(clientArgs: ClientArguments, hadoopConf: Configuration, spConf: 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

    Definition Classes
    ClientBase
  7. val STAGING_DIR_PERMISSION: FsPermission

    Definition Classes
    ClientBase
  8. val args: ClientArguments

    Definition Classes
    ClientClientBase
  9. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  10. def calculateAMMemory(newApp: GetNewApplicationResponse): Int

    Definition Classes
    ClientClientBase
  11. def clone(): AnyRef

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

    Definition Classes
    AbstractService → Service → Closeable
    Annotations
    @throws( classOf[java.io.IOException] )
  13. val conf: Configuration

    Definition Classes
    ClientClientBase
  14. def createApplication(): YarnClientApplication

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

    Definition Classes
    ClientBase
  16. val credentials: Credentials

    Definition Classes
    ClientBase
  17. final def eq(arg0: AnyRef): Boolean

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

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

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

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

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

    Definition Classes
    ClientBase
  23. def getApplicationReport(arg0: ApplicationId): ApplicationReport

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Definition Classes
    Any
  48. def isTraceEnabled(): Boolean

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

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

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

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

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

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

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

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  62. def memoryOverhead: Int

    Attributes
    protected
    Definition Classes
    ClientBase
  63. def monitorApplication(appId: ApplicationId): Boolean

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

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

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

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

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

    Definition Classes
    ClientBase
  69. def putBlocker(arg0: String, arg1: String): Unit

    Attributes
    protected[org.apache.hadoop.service]
    Definition Classes
    AbstractService
  70. def qualifyForLocal(localURI: URI): Path

    Definition Classes
    ClientBase
  71. def registerServiceListener(arg0: ServiceStateChangeListener): Unit

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

    Definition Classes
    AbstractService
  73. var rpc: YarnRPC

  74. def run(): Unit

  75. def runApp(): ApplicationId

  76. def serviceInit(arg0: Configuration): Unit

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

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

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

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

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

    Definition Classes
    ClientBase
  82. def setupSecurityToken(amContainer: ContainerLaunchContext): Unit

    Definition Classes
    ClientClientBase
  83. val sparkConf: SparkConf

    Definition Classes
    ClientClientBase
  84. def start(): Unit

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

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

  87. def submitApplication(arg0: ApplicationSubmissionContext): ApplicationId

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

    Definition Classes
    AnyRef
  89. def toString(): String

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

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

    Definition Classes
    ClientBase
  92. def validateArgs(): Unit

    Definition Classes
    ClientBase
  93. def verifyClusterResources(app: GetNewApplicationResponse): Unit

    Definition Classes
    ClientBase
  94. final def wait(): Unit

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

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

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

    Definition Classes
    AbstractService → Service
  98. val yarnConf: YarnConfiguration

    Definition Classes
    ClientClientBase

Inherited from ClientBase

Inherited from Logging

Inherited from YarnClientImpl

Inherited from YarnClient

Inherited from AbstractService

Inherited from Service

Inherited from Closeable

Inherited from AnyRef

Inherited from Any

Ungrouped