Class

org.apache.spark.scheduler.cluster

SnappyCoarseGrainedSchedulerBackend

Related Doc: package cluster

Permalink

class SnappyCoarseGrainedSchedulerBackend extends CoarseGrainedSchedulerBackend

Linear Supertypes
CoarseGrainedSchedulerBackend, internal.Logging, SchedulerBackend, ExecutorAllocationClient, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappyCoarseGrainedSchedulerBackend
  2. CoarseGrainedSchedulerBackend
  3. Logging
  4. SchedulerBackend
  5. ExecutorAllocationClient
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappyCoarseGrainedSchedulerBackend(scheduler: TaskSchedulerImpl, rpcEnv: RpcEnv)

    Permalink

Type Members

  1. class DriverEndpoint extends ThreadSafeRpcEndpoint with internal.Logging

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend

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. def applicationAttemptId(): Option[String]

    Permalink

    Get the attempt ID for this run, if the cluster manager supports multiple attempts.

    Get the attempt ID for this run, if the cluster manager supports multiple attempts. Applications run in client mode will not have attempt IDs.

    returns

    The application attempt id, if available.

    Definition Classes
    SchedulerBackend
  5. def applicationId(): String

    Permalink

    Overriding the spark app id function to provide a snappy specific app id.

    Overriding the spark app id function to provide a snappy specific app id.

    returns

    An application ID

    Definition Classes
    SnappyCoarseGrainedSchedulerBackend → SchedulerBackend
  6. final def asInstanceOf[T0]: T0

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. val conf: SparkConf

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  9. def createDriverEndpoint(properties: Seq[(String, String)]): DriverEndpoint

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyCoarseGrainedSchedulerBackend → CoarseGrainedSchedulerBackend
  10. def createDriverEndpointRef(properties: ArrayBuffer[(String, String)]): RpcEndpointRef

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  11. var currentExecutorIdCounter: Int

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  12. def defaultParallelism(): Int

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend → SchedulerBackend
  13. def doKillExecutors(executorIds: Seq[String]): Future[Boolean]

    Permalink

    Kill the given list of executors through the cluster manager.

    Kill the given list of executors through the cluster manager.

    returns

    whether the kill request is acknowledged.

    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  14. def doRequestTotalExecutors(requestedTotal: Int): Future[Boolean]

    Permalink

    Request executors from the cluster manager by specifying the total number desired, including existing pending and running executors.

    Request executors from the cluster manager by specifying the total number desired, including existing pending and running executors.

    The semantics here guarantee that we do not over-allocate executors for this application, since a later request overrides the value of any prior request. The alternative interface of requesting a delta of executors risks double counting new executors when there are insufficient resources to satisfy the first request. We make the assumption here that the cluster manager will eventually fulfill all requests when resources free up.

    returns

    a future whose evaluation indicates whether the request is acknowledged.

    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  15. var driverEndpoint: RpcEndpointRef

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend
  16. def driverUrl: String

    Permalink
  17. final def eq(arg0: AnyRef): Boolean

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

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  20. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  21. def getDriverLogUrls: Option[Map[String, String]]

    Permalink

    Get the URLs for the driver logs.

    Get the URLs for the driver logs. These URLs are used to display the links in the UI Executors tab for the driver.

    returns

    Map containing the log names and their respective URLs

    Definition Classes
    SchedulerBackend
  22. def getExecutorIds(): Seq[String]

    Permalink

    Get the list of currently active executors

    Get the list of currently active executors

    Definition Classes
    CoarseGrainedSchedulerBackend → ExecutorAllocationClient
  23. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  24. var hostToLocalTaskCount: Map[String, Int]

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  25. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean = false): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  26. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  27. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  28. def isReady(): Boolean

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend → SchedulerBackend
  29. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  30. def killExecutor(executorId: String): Boolean

    Permalink

    Request that the cluster manager kill the specified executor.

    Request that the cluster manager kill the specified executor.

    returns

    whether the request is acknowledged by the cluster manager.

    Definition Classes
    ExecutorAllocationClient
  31. final def killExecutors(executorIds: Seq[String], replace: Boolean, force: Boolean): Seq[String]

    Permalink

    Request that the cluster manager kill the specified executors.

    Request that the cluster manager kill the specified executors.

    When asking the executor to be replaced, the executor loss is considered a failure, and killed tasks that are running on the executor will count towards the failure limits. If no replacement is being requested, then the tasks will not count towards the limit.

    executorIds

    identifiers of executors to kill

    replace

    whether to replace the killed executors with new ones

    force

    whether to force kill busy executors

    returns

    whether the kill request is acknowledged. If list to kill is empty, it will return false.

    Definition Classes
    CoarseGrainedSchedulerBackend
  32. final def killExecutors(executorIds: Seq[String]): Seq[String]

    Permalink

    Request that the cluster manager kill the specified executors.

    Request that the cluster manager kill the specified executors.

    returns

    whether the kill request is acknowledged. If list to kill is empty, it will return false.

    Definition Classes
    CoarseGrainedSchedulerBackend → ExecutorAllocationClient
  33. def killTask(taskId: Long, executorId: String, interruptThread: Boolean): Unit

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend → SchedulerBackend
  34. var localityAwareTasks: Int

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  35. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  36. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  42. def logName: String

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  47. def minRegisteredRatio: Double

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  48. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  49. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  51. def removeExecutor(executorId: String, reason: ExecutorLossReason): Unit

    Permalink

    Called by subclasses when notified of a lost worker.

    Called by subclasses when notified of a lost worker. It just fires the message and returns at once.

    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  52. final def requestExecutors(numAdditionalExecutors: Int): Boolean

    Permalink

    Request an additional number of executors from the cluster manager.

    Request an additional number of executors from the cluster manager.

    returns

    whether the request is acknowledged.

    Definition Classes
    CoarseGrainedSchedulerBackend → ExecutorAllocationClient
  53. final def requestTotalExecutors(numExecutors: Int, localityAwareTasks: Int, hostToLocalTaskCount: Map[String, Int]): Boolean

    Permalink

    Update the cluster manager on our scheduling needs.

    Update the cluster manager on our scheduling needs. Three bits of information are included to help it make decisions.

    numExecutors

    The total number of executors we'd like to have. The cluster manager shouldn't kill any running executor to reach this number, but, if all existing executors were to die, this is the number of executors we'd want to be allocated.

    localityAwareTasks

    The number of tasks in all active stages that have a locality preferences. This includes running, pending, and completed tasks.

    hostToLocalTaskCount

    A map of hosts to the number of tasks from all active stages that would like to like to run on that host. This includes running, pending, and completed tasks.

    returns

    whether the request is acknowledged by the cluster manager.

    Definition Classes
    CoarseGrainedSchedulerBackend → ExecutorAllocationClient
  54. def reset(): Unit

    Permalink

    Reset the state of CoarseGrainedSchedulerBackend to the initial state.

    Reset the state of CoarseGrainedSchedulerBackend to the initial state. Currently it will only be called in the yarn-client mode when AM re-registers after a failure.

    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  55. def reviveOffers(): Unit

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend → SchedulerBackend
  56. val rpcEnv: RpcEnv

    Permalink
    Definition Classes
    SnappyCoarseGrainedSchedulerBackend → CoarseGrainedSchedulerBackend
  57. def start(): Unit

    Permalink
    Definition Classes
    SnappyCoarseGrainedSchedulerBackend → CoarseGrainedSchedulerBackend → SchedulerBackend
  58. def stop(): Unit

    Permalink
    Definition Classes
    SnappyCoarseGrainedSchedulerBackend → CoarseGrainedSchedulerBackend → SchedulerBackend
  59. def stopExecutors(): Unit

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend
  60. def sufficientResourcesRegistered(): Boolean

    Permalink
    Definition Classes
    CoarseGrainedSchedulerBackend
  61. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  63. val totalCoreCount: AtomicInteger

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  64. val totalRegisteredExecutors: AtomicInteger

    Permalink
    Attributes
    protected
    Definition Classes
    CoarseGrainedSchedulerBackend
  65. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from CoarseGrainedSchedulerBackend

Inherited from internal.Logging

Inherited from SchedulerBackend

Inherited from ExecutorAllocationClient

Inherited from AnyRef

Inherited from Any

Ungrouped