class ManifestFileCommitProtocol extends FileCommitProtocol with Serializable with Logging
A FileCommitProtocol that tracks the list of valid files in a manifest file, used in structured streaming.
          
            Linear Supertypes
          
          
        
          
          
            
          
          
        
        
            Ordering
            
          - Alphabetic
- By Inheritance
                  Inherited
                  
                  
- ManifestFileCommitProtocol
- Serializable
- Serializable
- FileCommitProtocol
- Logging
- AnyRef
- Any
- Hide All
- Show All
              Visibility
              
        - Public
- All
Instance Constructors
- 
      
      
      
        
      
    
      
        
        new
      
      
        ManifestFileCommitProtocol(jobId: String, path: String)
      
      
      - path
- path to write the final output to. 
 
Value Members
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        !=(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ##(): Int
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ==(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        abortJob(jobContext: JobContext): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        abortTask(taskContext: TaskAttemptContext): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        asInstanceOf[T0]: T0
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        clone(): AnyRef
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        commitJob(jobContext: JobContext, taskCommits: Seq[TaskCommitMessage]): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        commitTask(taskContext: TaskAttemptContext): TaskCommitMessage
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        deleteWithJob(fs: FileSystem, path: Path, recursive: Boolean): Boolean
      
      
      - Definition Classes
- FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        eq(arg0: AnyRef): Boolean
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        equals(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        finalize(): Unit
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        getClass(): Class[_]
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        hashCode(): Int
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        isInstanceOf[T0]: Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        isTraceEnabled(): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        log: Logger
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logDebug(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logDebug(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logError(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logError(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logInfo(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logInfo(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logName: String
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logTrace(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logTrace(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logWarning(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logWarning(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ne(arg0: AnyRef): Boolean
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        newTaskTempFile(taskContext: TaskAttemptContext, dir: Option[String], ext: String): String
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        newTaskTempFile(taskContext: TaskAttemptContext, dir: Option[String], spec: FileNameSpec): String
      
      
      - Definition Classes
- FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        newTaskTempFileAbsPath(taskContext: TaskAttemptContext, absoluteDir: String, ext: String): String
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        newTaskTempFileAbsPath(taskContext: TaskAttemptContext, absoluteDir: String, spec: FileNameSpec): String
      
      
      - Definition Classes
- FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notify(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notifyAll(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        onTaskCommit(taskCommit: TaskCommitMessage): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        setupJob(jobContext: JobContext): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        setupManifestOptions(fileLog: FileStreamSinkLog, batchId: Long): Unit
      
      
      Sets up the manifest log output and the batch id for this job. Sets up the manifest log output and the batch id for this job. Must be called before any other function. 
- 
      
      
      
        
      
    
      
        
        def
      
      
        setupTask(taskContext: TaskAttemptContext): Unit
      
      
      - Definition Classes
- ManifestFileCommitProtocol → FileCommitProtocol
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        synchronized[T0](arg0: ⇒ T0): T0
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toString(): String
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(arg0: Long, arg1: Int): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(arg0: Long): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()