You are viewing a plain text version of this content. The canonical link for it is here.
Posted to reviews@spark.apache.org by rdblue <gi...@git.apache.org> on 2018/05/10 21:29:20 UTC

[GitHub] spark pull request #21118: SPARK-23325: Use InternalRow when reading with Da...

Github user rdblue commented on a diff in the pull request:

    https://github.com/apache/spark/pull/21118#discussion_r187465762
  
    --- Diff: sql/core/src/main/java/org/apache/spark/sql/sources/v2/reader/SupportsScanUnsafeRow.java ---
    @@ -1,46 +0,0 @@
    -/*
    - * Licensed to the Apache Software Foundation (ASF) under one or more
    - * contributor license agreements.  See the NOTICE file distributed with
    - * this work for additional information regarding copyright ownership.
    - * The ASF licenses this file to You under the Apache License, Version 2.0
    - * (the "License"); you may not use this file except in compliance with
    - * the License.  You may obtain a copy of the License at
    - *
    - *    http://www.apache.org/licenses/LICENSE-2.0
    - *
    - * Unless required by applicable law or agreed to in writing, software
    - * distributed under the License is distributed on an "AS IS" BASIS,
    - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
    - * See the License for the specific language governing permissions and
    - * limitations under the License.
    - */
    -
    -package org.apache.spark.sql.sources.v2.reader;
    -
    -import java.util.List;
    -
    -import org.apache.spark.annotation.InterfaceStability;
    -import org.apache.spark.sql.Row;
    -import org.apache.spark.sql.catalyst.expressions.UnsafeRow;
    -
    -/**
    - * A mix-in interface for {@link DataSourceReader}. Data source readers can implement this
    - * interface to output {@link UnsafeRow} directly and avoid the row copy at Spark side.
    - * This is an experimental and unstable interface, as {@link UnsafeRow} is not public and may get
    - * changed in the future Spark versions.
    - */
    -@InterfaceStability.Unstable
    -public interface SupportsScanUnsafeRow extends DataSourceReader {
    --- End diff --
    
    The check I was referring to is implemented in generated code. The projection added in `DataSourceV2Strategy` handles the cases where part or all of the incoming row is `UnsafeRow`.


---

---------------------------------------------------------------------
To unsubscribe, e-mail: reviews-unsubscribe@spark.apache.org
For additional commands, e-mail: reviews-help@spark.apache.org