You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@drill.apache.org by "ASF GitHub Bot (JIRA)" <ji...@apache.org> on 2015/10/26 23:20:27 UTC

[jira] [Commented] (DRILL-3963) Read raw key value bytes from sequence files

    [ https://issues.apache.org/jira/browse/DRILL-3963?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=14975209#comment-14975209 ] 

ASF GitHub Bot commented on DRILL-3963:
---------------------------------------

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

    https://github.com/apache/drill/pull/214#discussion_r43061625
  
    --- Diff: exec/java-exec/src/main/java/org/apache/drill/exec/store/easy/sequencefile/SequenceFileRecordReader.java ---
    @@ -0,0 +1,141 @@
    +/**
    + * 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.drill.exec.store.easy.sequencefile;
    +
    +import java.io.IOException;
    +import java.util.List;
    +import java.util.ArrayList;
    +
    +import com.google.common.base.Stopwatch;
    +import org.apache.drill.common.exceptions.DrillRuntimeException;
    +import org.apache.drill.common.exceptions.ExecutionSetupException;
    +import org.apache.drill.common.expression.SchemaPath;
    +import org.apache.drill.common.types.TypeProtos;
    +import org.apache.drill.common.types.Types;
    +import org.apache.drill.exec.ops.OperatorContext;
    +import org.apache.drill.exec.physical.impl.OutputMutator;
    +import org.apache.drill.exec.record.MaterializedField;
    +import org.apache.drill.exec.store.AbstractRecordReader;
    +import org.apache.drill.common.types.TypeProtos.MajorType;
    +import org.apache.drill.exec.vector.NullableVarBinaryVector;
    +import org.apache.hadoop.conf.Configuration;
    +import org.apache.hadoop.io.BytesWritable;
    +import org.apache.hadoop.mapred.JobConf;
    +import org.apache.hadoop.mapred.FileSplit;
    +import org.apache.hadoop.mapred.Reporter;
    +import org.apache.hadoop.mapred.SequenceFileAsBinaryInputFormat;
    +
    +
    +public class SequenceFileRecordReader extends AbstractRecordReader {
    +  private static final org.slf4j.Logger logger = org.slf4j.LoggerFactory.getLogger(SequenceFileRecordReader.class);
    +
    +  private static final int PER_BATCH_RECORD_COUNT = 4096;
    +  private static final int PER_BATCH_BYTES = 256*1024;
    +
    +  private static final MajorType KEY_TYPE = Types.optional(TypeProtos.MinorType.VARBINARY);
    +  private static final MajorType VALUE_TYPE = Types.optional(TypeProtos.MinorType.VARBINARY);
    +
    +  private final SchemaPath keySchema = SchemaPath.getSimplePath("binary_key");
    +  private final SchemaPath valueSchema = SchemaPath.getSimplePath("binary_value");
    +
    +  private NullableVarBinaryVector keyVector;
    +  private NullableVarBinaryVector valueVector;
    +  private FileSplit split;
    +  private org.apache.hadoop.mapred.RecordReader<BytesWritable, BytesWritable> reader;
    +  private BytesWritable key = new BytesWritable();
    +  private BytesWritable value = new BytesWritable();
    +
    +  public SequenceFileRecordReader(final FileSplit split,
    +                                  final Configuration fsConf) {
    +    final List<SchemaPath> columns = new ArrayList();
    +    columns.add(keySchema);
    +    columns.add(valueSchema);
    +    setColumns(columns);
    +    SequenceFileAsBinaryInputFormat inputFormat = new SequenceFileAsBinaryInputFormat();
    +    this.split = split;
    +    JobConf jobConf = new JobConf(fsConf);
    +    jobConf.setInputFormat(inputFormat.getClass());
    +    try {
    +      this.reader = inputFormat.getRecordReader(split, jobConf, Reporter.NULL);
    --- End diff --
    
    Can this be moved to setup?


> Read raw key value bytes from sequence files
> --------------------------------------------
>
>                 Key: DRILL-3963
>                 URL: https://issues.apache.org/jira/browse/DRILL-3963
>             Project: Apache Drill
>          Issue Type: New Feature
>            Reporter: amit hadke
>            Assignee: amit hadke
>
> Sequence files store list of key-value pairs. Keys/values are of type hadoop writable.
> Provide a format plugin that reads raw bytes out of sequence files which can be further deserialized by a udf(from hadoop writable -> drill type)



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)