File tree Expand file tree Collapse file tree 2 files changed +6
-6
lines changed
sql/core/src/main/java/org/apache/spark/sql/sources/v2/reader Expand file tree Collapse file tree 2 files changed +6
-6
lines changed Original file line number Diff line number Diff line change 3636public interface InputPartition <T > extends Serializable {
3737
3838 /**
39- * The preferred locations where the input partition reader returned by this partition can run faster,
40- * but Spark does not guarantee to run the input partition reader on these locations.
39+ * The preferred locations where the input partition reader returned by this partition can run
40+ * faster, but Spark does not guarantee to run the input partition reader on these locations.
4141 * The implementations should make sure that it can be run on any location.
4242 * The location is a string representing the host name.
4343 *
Original file line number Diff line number Diff line change 2323import org .apache .spark .annotation .InterfaceStability ;
2424
2525/**
26- * An input partition reader returned by {@link InputPartition#createPartitionReader()} and is responsible for
27- * outputting data for a RDD partition.
26+ * An input partition reader returned by {@link InputPartition#createPartitionReader()} and is
27+ * responsible for outputting data for a RDD partition.
2828 *
2929 * Note that, Currently the type `T` can only be {@link org.apache.spark.sql.Row} for normal input
30- * partition readers, or {@link org.apache.spark.sql.catalyst.expressions.UnsafeRow} for input partition
31- * readers that mix in {@link SupportsScanUnsafeRow}.
30+ * partition readers, or {@link org.apache.spark.sql.catalyst.expressions.UnsafeRow} for input
31+ * partition readers that mix in {@link SupportsScanUnsafeRow}.
3232 */
3333@ InterfaceStability .Evolving
3434public interface InputPartitionReader <T > extends Closeable {
You can’t perform that action at this time.
0 commit comments