org.apache.spark.scheduler

JobLogger

class JobLogger extends SparkListener with Logging

Linear Supertypes
Logging, SparkListener, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. Hide All
  2. Show all
  1. JobLogger
  2. Logging
  3. SparkListener
  4. AnyRef
  5. Any
Visibility
  1. Public
  2. All

Instance Constructors

  1. new JobLogger()

  2. new JobLogger(logDirName: String)

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. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def buildJobDep(jobID: Int, stage: Stage): Unit

    Attributes
    protected
  8. def clone(): AnyRef

    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws()
  9. def closeLogWriter(jobID: Int): Unit

    Attributes
    protected
  10. def createLogDir(): Unit

    Attributes
    protected
  11. def createLogWriter(jobID: Int): Unit

    Attributes
    protected
  12. final def eq(arg0: AnyRef): Boolean

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

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

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

    Definition Classes
    AnyRef → Any
  16. def getEventQueue: LinkedBlockingQueue[SparkListenerEvents]

  17. def getJobIDToStages: HashMap[Int, ListBuffer[Stage]]

  18. def getJobIDtoPrintWriter: HashMap[Int, PrintWriter]

  19. def getLogDir: String

  20. def getRddName(rdd: org.apache.spark.rdd.RDD[_]): String

    Attributes
    protected
  21. def getStageIDToJobID: HashMap[Int, Int]

  22. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  23. def indentString(indent: Int): String

    Attributes
    protected
  24. def initLogging(): Unit

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

    Definition Classes
    Any
  26. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  27. def jobLogInfo(jobID: Int, info: String, withTime: Boolean = true): Unit

    Attributes
    protected
  28. def log: Logger

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

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

    Attributes
    protected
    Definition Classes
    Logging
  31. val logDirName: String

  32. def logError(msg: ⇒ String, throwable: Throwable): Unit

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

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  40. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  41. final def notify(): Unit

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

    Definition Classes
    AnyRef
  43. def onJobEnd(jobEnd: SparkListenerJobEnd): Unit

    Called when a job ends

    Called when a job ends

    Definition Classes
    JobLoggerSparkListener
  44. def onJobStart(jobStart: SparkListenerJobStart): Unit

    Called when a job starts

    Called when a job starts

    Definition Classes
    JobLoggerSparkListener
  45. def onStageCompleted(stageCompleted: StageCompleted): Unit

    Called when a stage is completed, with information on the completed stage

    Called when a stage is completed, with information on the completed stage

    Definition Classes
    JobLoggerSparkListener
  46. def onStageSubmitted(stageSubmitted: SparkListenerStageSubmitted): Unit

    Called when a stage is submitted

    Called when a stage is submitted

    Definition Classes
    JobLoggerSparkListener
  47. def onTaskEnd(taskEnd: SparkListenerTaskEnd): Unit

    Called when a task ends

    Called when a task ends

    Definition Classes
    JobLoggerSparkListener
  48. def onTaskStart(taskStart: SparkListenerTaskStart): Unit

    Called when a task starts

    Called when a task starts

    Definition Classes
    JobLoggerSparkListener
  49. def recordJobProperties(jobID: Int, properties: Properties): Unit

    Attributes
    protected
  50. def recordRddInStageGraph(jobID: Int, rdd: org.apache.spark.rdd.RDD[_], indent: Int): Unit

    Attributes
    protected
  51. def recordStageDep(jobID: Int): Unit

    Attributes
    protected
  52. def recordStageDepGraph(jobID: Int, stage: Stage, indent: Int = 0): Unit

    Attributes
    protected
  53. def recordTaskMetrics(stageID: Int, status: String, taskInfo: TaskInfo, taskMetrics: TaskMetrics): Unit

    Attributes
    protected
  54. def stageLogInfo(stageID: Int, info: String, withTime: Boolean = true): Unit

    Attributes
    protected
  55. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  56. def toString(): String

    Definition Classes
    AnyRef → Any
  57. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws()

Inherited from Logging

Inherited from SparkListener

Inherited from AnyRef

Inherited from Any