class CoGroupedArrowPythonRunner extends BasePythonRunner[(Iterator[InternalRow], Iterator[InternalRow]), ColumnarBatch] with BasicPythonArrowOutput
Python UDF Runner for cogrouped udfs. It sends Arrow bathes from two different DataFrames, groups them in Python, and receive it back in JVM as batches of single DataFrame.
Linear Supertypes
Ordering
- Alphabetic
- By Inheritance
Inherited
- CoGroupedArrowPythonRunner
- BasicPythonArrowOutput
- PythonArrowOutput
- BasePythonRunner
- Logging
- AnyRef
- Any
- Hide All
- Show All
Visibility
- Public
- Protected
Instance Constructors
- new CoGroupedArrowPythonRunner(funcs: Seq[(ChainedPythonFunctions, Long)], evalType: Int, argOffsets: Array[Array[Int]], leftSchema: StructType, rightSchema: StructType, timeZoneId: String, largeVarTypes: Boolean, conf: Map[String, String], pythonMetrics: Map[String, SQLMetric], jobArtifactUUID: Option[String], profiler: Option[String])
Type Members
- implicit class LogStringContext extends AnyRef
- Definition Classes
- Logging
- class MonitorThread extends Thread
- Definition Classes
- BasePythonRunner
- class ReaderInputStream extends InputStream
- Definition Classes
- BasePythonRunner
- abstract class ReaderIterator extends Iterator[OUT]
- Definition Classes
- BasePythonRunner
- abstract class Writer extends AnyRef
- Definition Classes
- BasePythonRunner
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
- val accumulator: PythonAccumulator
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val argOffsets: Array[Array[Int]]
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- val authSocketTimeout: Long
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val batchSizeForPythonUDF: Int
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val bufferSize: Int
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- def compute(inputIterator: Iterator[(Iterator[InternalRow], Iterator[InternalRow])], partitionIndex: Int, context: TaskContext): Iterator[ColumnarBatch]
- Definition Classes
- BasePythonRunner
- def deserializeColumnarBatch(batch: ColumnarBatch, schema: StructType): ColumnarBatch
- Attributes
- protected
- Definition Classes
- BasicPythonArrowOutput → PythonArrowOutput
- val envVars: Map[String, String]
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- val evalType: Int
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val faultHandlerEnabled: Boolean
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- val funcs: Seq[ChainedPythonFunctions]
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def handleMetadataAfterExec(stream: DataInputStream): Unit
- Attributes
- protected
- Definition Classes
- PythonArrowOutput
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- val hideTraceback: Boolean
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- val idleTimeoutSeconds: Long
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- 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
- val jobArtifactUUID: Option[String]
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- def log: Logger
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry): 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(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(entry: LogEntry): 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(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(entry: LogEntry): 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(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(entry: LogEntry): 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(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- val metrics: Map[String, AccumulatorV2[Long, Long]]
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def newReaderIterator(stream: DataInputStream, writer: Writer, startTime: Long, env: SparkEnv, worker: PythonWorker, pid: Option[Int], releasedOrClosed: AtomicBoolean, context: TaskContext): Iterator[ColumnarBatch]
- Attributes
- protected
- Definition Classes
- PythonArrowOutput
- def newWriter(env: SparkEnv, worker: PythonWorker, inputIterator: Iterator[(Iterator[InternalRow], Iterator[InternalRow])], partitionIndex: Int, context: TaskContext): Writer
- Attributes
- protected
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- val pythonExec: String
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- val pythonMetrics: Map[String, SQLMetric]
- Definition Classes
- CoGroupedArrowPythonRunner → PythonArrowOutput
- val pythonVer: String
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val simplifiedTraceback: Boolean
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- val timelyFlushEnabled: Boolean
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- val timelyFlushTimeoutNanos: Long
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- def toString(): String
- Definition Classes
- AnyRef → Any
- 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()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- def withLogContext(context: Map[String, String])(body: => Unit): Unit
- Attributes
- protected
- Definition Classes
- Logging
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)