class AvailableNowMicroBatchStreamWrapper extends AvailableNowDataStreamWrapper with MicroBatchStream
This class wraps a MicroBatchStream and makes it supports Trigger.AvailableNow.
See AvailableNowDataStreamWrapper for more details.
- Alphabetic
- By Inheritance
- AvailableNowMicroBatchStreamWrapper
- MicroBatchStream
- AvailableNowDataStreamWrapper
- Logging
- SupportsTriggerAvailableNow
- SupportsAdmissionControl
- SparkDataStream
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
- new AvailableNowMicroBatchStreamWrapper(delegate: MicroBatchStream)
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(classOf[java.lang.CloneNotSupportedException]) @native()
- def commit(end: connector.read.streaming.Offset): Unit
- Definition Classes
- AvailableNowDataStreamWrapper → SparkDataStream
- def createReaderFactory(): PartitionReaderFactory
- Definition Classes
- AvailableNowMicroBatchStreamWrapper → MicroBatchStream
- val delegate: SparkDataStream
- Definition Classes
- AvailableNowDataStreamWrapper
- def deserializeOffset(json: String): connector.read.streaming.Offset
- Definition Classes
- AvailableNowDataStreamWrapper → SparkDataStream
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable])
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def getDefaultReadLimit(): ReadLimit
Always return ReadLimit.allAvailable
Always return ReadLimit.allAvailable
- Definition Classes
- AvailableNowDataStreamWrapper → SupportsAdmissionControl
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def initialOffset(): connector.read.streaming.Offset
- Definition Classes
- AvailableNowDataStreamWrapper → 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(): connector.read.streaming.Offset
- Definition Classes
- AvailableNowMicroBatchStreamWrapper → MicroBatchStream
- 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 planInputPartitions(start: connector.read.streaming.Offset, end: connector.read.streaming.Offset): Array[InputPartition]
- Definition Classes
- AvailableNowMicroBatchStreamWrapper → MicroBatchStream
- 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 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(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()