class CoGroupedArrowPythonRunner extends BasePythonRunner[(Iterator[InternalRow], Iterator[InternalRow]), ColumnarBatch] with PythonArrowOutput
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
- PythonArrowOutput
- BasePythonRunner
- Logging
- AnyRef
- Any
- Hide All
- Show All
Visibility
- Public
- Protected
Instance Constructors
- new CoGroupedArrowPythonRunner(funcs: Seq[ChainedPythonFunctions], evalType: Int, argOffsets: Array[Array[Int]], leftSchema: StructType, rightSchema: StructType, timeZoneId: String, conf: Map[String, String])
Type Members
- class MonitorThread extends Thread
- Definition Classes
- BasePythonRunner
- abstract class ReaderIterator extends Iterator[OUT]
- Definition Classes
- BasePythonRunner
- class WriterMonitorThread extends Thread
- Definition Classes
- BasePythonRunner
- abstract class WriterThread extends Thread
- 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: PythonAccumulatorV2
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- val authSocketTimeout: Long
- 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]) @native()
- def compute(inputIterator: Iterator[(Iterator[InternalRow], Iterator[InternalRow])], partitionIndex: Int, context: TaskContext): Iterator[ColumnarBatch]
- Definition Classes
- BasePythonRunner
- 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
- 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 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 newReaderIterator(stream: DataInputStream, writerThread: WriterThread, startTime: Long, env: SparkEnv, worker: Socket, pid: Option[Int], releasedOrClosed: AtomicBoolean, context: TaskContext): Iterator[ColumnarBatch]
- Attributes
- protected
- Definition Classes
- PythonArrowOutput
- def newWriterThread(env: SparkEnv, worker: Socket, inputIterator: Iterator[(Iterator[InternalRow], Iterator[InternalRow])], partitionIndex: Int, context: TaskContext): WriterThread
- Attributes
- protected
- Definition Classes
- CoGroupedArrowPythonRunner → BasePythonRunner
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- val pythonExec: String
- Attributes
- protected
- Definition Classes
- BasePythonRunner
- 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
- 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()