Packages

c

org.apache.spark.sql.execution.python

ArrowPythonRunner

class ArrowPythonRunner extends BasePythonRunner[Iterator[InternalRow], ColumnarBatch] with PythonArrowOutput

Similar to PythonUDFRunner, but exchange data with Python worker via Arrow stream.

Linear Supertypes
PythonArrowOutput, BasePythonRunner[Iterator[InternalRow], ColumnarBatch], Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ArrowPythonRunner
  2. PythonArrowOutput
  3. BasePythonRunner
  4. Logging
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ArrowPythonRunner(funcs: Seq[ChainedPythonFunctions], evalType: Int, argOffsets: Array[Array[Int]], schema: StructType, timeZoneId: String, conf: Map[String, String])

Type Members

  1. class MonitorThread extends Thread
    Definition Classes
    BasePythonRunner
  2. abstract class ReaderIterator extends Iterator[OUT]
    Definition Classes
    BasePythonRunner
  3. abstract class WriterThread extends Thread
    Definition Classes
    BasePythonRunner

Value Members

  1. val bufferSize: Int
    Definition Classes
    ArrowPythonRunner → BasePythonRunner
  2. def compute(inputIterator: Iterator[Iterator[InternalRow]], partitionIndex: Int, context: TaskContext): Iterator[ColumnarBatch]
    Definition Classes
    BasePythonRunner