class AvailableNowSourceWrapper extends AvailableNowDataStreamWrapper with Source
This class wraps a Source and makes it supports Trigger.AvailableNow.
See AvailableNowDataStreamWrapper for more details.
- Alphabetic
- By Inheritance
- AvailableNowSourceWrapper
- Source
- AvailableNowDataStreamWrapper
- Logging
- SupportsTriggerAvailableNow
- SupportsAdmissionControl
- SparkDataStream
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
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
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        asInstanceOf[T0]: T0
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        clone(): AnyRef
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        commit(end: connector.read.streaming.Offset): Unit
      
      
      - Definition Classes
- Source → SparkDataStream
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        commit(end: Offset): Unit
      
      
      Informs the source that Spark has completed processing all data for offsets less than or equal to endand will only request offsets greater thanendin the future.Informs the source that Spark has completed processing all data for offsets less than or equal to endand will only request offsets greater thanendin the future.- Definition Classes
- Source
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        delegate: SparkDataStream
      
      
      - Definition Classes
- AvailableNowDataStreamWrapper
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        deserializeOffset(json: String): connector.read.streaming.Offset
      
      
      - Definition Classes
- Source → SparkDataStream
 
- 
      
      
      
        
      
    
      
        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] )
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        getBatch(start: Option[Offset], end: Offset): DataFrame
      
      
      Returns the data that is between the offsets ( start,end].Returns the data that is between the offsets ( start,end]. WhenstartisNone, then the batch should begin with the first record. This method must always return the same data for a particularstartandendpair; even after the Source has been restarted on a different node.Higher layers will always call this method with a value of startgreater than or equal to the last value passed tocommitand a value ofendless than or equal to the last value returned bygetOffsetIt is possible for the Offset type to be a SerializedOffset when it was obtained from the log. Moreover, StreamExecution only compares the Offset JSON representation to determine if the two objects are equal. This could have ramifications when upgrading Offset JSON formats i.e., two equivalent Offset objects could differ between version. Consequently, StreamExecution may call this method with two such equivalent Offset objects. In which case, the Source should return an empty DataFrame - Definition Classes
- AvailableNowSourceWrapper → Source
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        getClass(): Class[_]
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        getDefaultReadLimit(): ReadLimit
      
      
      Always return ReadLimit.allAvailable Always return ReadLimit.allAvailable - Definition Classes
- AvailableNowDataStreamWrapper → SupportsAdmissionControl
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        getOffset: Option[Offset]
      
      
      Returns the maximum available offset for this source. Returns the maximum available offset for this source. Returns Noneif this source has never received any data.- Definition Classes
- AvailableNowSourceWrapper → Source
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        hashCode(): Int
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initialOffset(): connector.read.streaming.Offset
      
      
      - Definition Classes
- Source → SparkDataStream
 
- 
      
      
      
        
      
    
      
        
        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
      
      
        latestOffset(startOffset: connector.read.streaming.Offset, limit: ReadLimit): connector.read.streaming.Offset
      
      
      Return the latest offset pre-fetched in prepareForTriggerAvailableNow. Return the latest offset pre-fetched in prepareForTriggerAvailableNow. - Definition Classes
- AvailableNowDataStreamWrapper → SupportsAdmissionControl
 
- 
      
      
      
        
      
    
      
        
        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
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notify(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notifyAll(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        prepareForTriggerAvailableNow(): Unit
      
      
      Fetch and store the latest offset for all available data at the beginning of the query. Fetch and store the latest offset for all available data at the beginning of the query. - Definition Classes
- AvailableNowDataStreamWrapper → SupportsTriggerAvailableNow
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        reportLatestOffset(): connector.read.streaming.Offset
      
      
      - Definition Classes
- AvailableNowDataStreamWrapper → SupportsAdmissionControl
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        schema: StructType
      
      
      Returns the schema of the data from this source Returns the schema of the data from this source - Definition Classes
- AvailableNowSourceWrapper → Source
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        stop(): Unit
      
      
      - Definition Classes
- AvailableNowDataStreamWrapper → SparkDataStream
 
- 
      
      
      
        
      
    
      
        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()