All Downloads are FREE. Search and download functionalities are using the official Maven repository.

parquet.hadoop.ParquetFileReader Maven / Gradle / Ivy

There is a newer version: 1.6.0
Show newest version
/**
 * Copyright 2012 Twitter, Inc.
 *
 * Licensed 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 parquet.hadoop;

import static parquet.Log.DEBUG;
import static parquet.bytes.BytesUtils.readIntLittleEndian;
import static parquet.format.converter.ParquetMetadataConverter.NO_FILTER;
import static parquet.format.converter.ParquetMetadataConverter.SKIP_ROW_GROUPS;
import static parquet.hadoop.ParquetFileWriter.*;

import java.io.ByteArrayInputStream;
import java.io.Closeable;
import java.io.IOException;
import java.io.SequenceInputStream;
import java.util.ArrayList;
import java.util.Arrays;
import java.util.Collection;
import java.util.Collections;
import java.util.Date;
import java.util.HashMap;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
import java.util.Map.Entry;
import java.util.Set;
import java.util.concurrent.Callable;
import java.util.concurrent.ExecutionException;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.Future;

import org.apache.hadoop.conf.Configuration;
import org.apache.hadoop.fs.FSDataInputStream;
import org.apache.hadoop.fs.FileStatus;
import org.apache.hadoop.fs.FileSystem;
import org.apache.hadoop.fs.Path;
import org.apache.hadoop.fs.PathFilter;
import org.apache.hadoop.mapred.Utils;

import parquet.Log;
import parquet.bytes.BytesInput;
import parquet.column.ColumnDescriptor;
import parquet.column.page.DictionaryPage;
import parquet.column.page.Page;
import parquet.column.page.PageReadStore;
import parquet.common.schema.ColumnPath;
import parquet.format.PageHeader;
import parquet.format.Util;
import parquet.format.converter.ParquetMetadataConverter;
import parquet.format.converter.ParquetMetadataConverter.MetadataFilter;
import parquet.hadoop.CodecFactory.BytesDecompressor;
import parquet.hadoop.ColumnChunkPageReadStore.ColumnChunkPageReader;
import parquet.hadoop.metadata.BlockMetaData;
import parquet.hadoop.metadata.ColumnChunkMetaData;
import parquet.hadoop.metadata.ParquetMetadata;
import parquet.hadoop.util.counters.BenchmarkCounter;
import parquet.io.ParquetDecodingException;

/**
 * Internal implementation of the Parquet file reader as a block container
 *
 * @author Julien Le Dem
 *
 */
public class ParquetFileReader implements Closeable {

  private static final Log LOG = Log.getLog(ParquetFileReader.class);

  private static ParquetMetadataConverter parquetMetadataConverter = new ParquetMetadataConverter();

  /**
   * for files provided, check if there's a summary file.
   * If a summary file is found it is used otherwise the file footer is used.
   * @param configuration the hadoop conf to connect to the file system;
   * @param partFiles the part files to read
   * @return the footers for those files using the summary file if possible.
   * @throws IOException
   */
  @Deprecated
  public static List
readAllFootersInParallelUsingSummaryFiles(Configuration configuration, List partFiles) throws IOException { return readAllFootersInParallelUsingSummaryFiles(configuration, partFiles, false); } private static MetadataFilter filter(boolean skipRowGroups) { return skipRowGroups ? SKIP_ROW_GROUPS : NO_FILTER; } /** * for files provided, check if there's a summary file. * If a summary file is found it is used otherwise the file footer is used. * @param configuration the hadoop conf to connect to the file system; * @param partFiles the part files to read * @param skipRowGroups to skipRowGroups in the footers * @return the footers for those files using the summary file if possible. * @throws IOException */ public static List
readAllFootersInParallelUsingSummaryFiles( final Configuration configuration, final Collection partFiles, final boolean skipRowGroups) throws IOException { // figure out list of all parents to part files Set parents = new HashSet(); for (FileStatus part : partFiles) { parents.add(part.getPath().getParent()); } // read corresponding summary files if they exist List>> summaries = new ArrayList>>(); for (final Path path : parents) { summaries.add(new Callable>() { @Override public Map call() throws Exception { ParquetMetadata mergedMetadata = readSummaryMetadata(configuration, path, skipRowGroups); if (mergedMetadata != null) { final List
footers; if (skipRowGroups) { footers = new ArrayList
(); for (FileStatus f : partFiles) { footers.add(new Footer(f.getPath(), mergedMetadata)); } } else { footers = footersFromSummaryFile(path, mergedMetadata); } Map map = new HashMap(); for (Footer footer : footers) { // the folder may have been moved footer = new Footer(new Path(path, footer.getFile().getName()), footer.getParquetMetadata()); map.put(footer.getFile(), footer); } return map; } else { return Collections.emptyMap(); } } }); } Map cache = new HashMap(); try { List> footersFromSummaries = runAllInParallel(5, summaries); for (Map footers : footersFromSummaries) { cache.putAll(footers); } } catch (ExecutionException e) { throw new IOException("Error reading summaries", e); } // keep only footers for files actually requested and read file footer if not found in summaries List
result = new ArrayList
(partFiles.size()); List toRead = new ArrayList(); for (FileStatus part : partFiles) { Footer f = cache.get(part.getPath()); if (f != null) { result.add(f); } else { toRead.add(part); } } if (toRead.size() > 0) { // read the footers of the files that did not have a summary file if (Log.INFO) LOG.info("reading another " + toRead.size() + " footers"); result.addAll(readAllFootersInParallel(configuration, toRead, skipRowGroups)); } return result; } private static List runAllInParallel(int parallelism, List> toRun) throws ExecutionException { ExecutorService threadPool = Executors.newFixedThreadPool(parallelism); try { List> futures = new ArrayList>(); for (Callable callable : toRun) { futures.add(threadPool.submit(callable)); } List result = new ArrayList(toRun.size()); for (Future future : futures) { try { result.add(future.get()); } catch (InterruptedException e) { throw new RuntimeException("The thread was interrupted", e); } } return result; } finally { threadPool.shutdownNow(); } } @Deprecated public static List
readAllFootersInParallel(final Configuration configuration, List partFiles) throws IOException { return readAllFootersInParallel(configuration, partFiles, false); } /** * read all the footers of the files provided * (not using summary files) * @param configuration the conf to access the File System * @param partFiles the files to read * @param skipRowGroups to skip the rowGroup info * @return the footers * @throws IOException */ public static List
readAllFootersInParallel(final Configuration configuration, List partFiles, final boolean skipRowGroups) throws IOException { List> footers = new ArrayList>(); for (final FileStatus currentFile : partFiles) { footers.add(new Callable
() { @Override public Footer call() throws Exception { try { return new Footer(currentFile.getPath(), readFooter(configuration, currentFile, filter(skipRowGroups))); } catch (IOException e) { throw new IOException("Could not read footer for file " + currentFile, e); } } }); } try { return runAllInParallel(5, footers); } catch (ExecutionException e) { throw new IOException("Could not read footer: " + e.getMessage(), e.getCause()); } } /** * Read the footers of all the files under that path (recursively) * not using summary files. * rowGroups are not skipped * @param configuration the configuration to access the FS * @param fileStatus the root dir * @return all the footers * @throws IOException */ public static List
readAllFootersInParallel(Configuration configuration, FileStatus fileStatus) throws IOException { List statuses = listFiles(configuration, fileStatus); return readAllFootersInParallel(configuration, statuses, false); } @Deprecated public static List
readFooters(Configuration configuration, Path path) throws IOException { return readFooters(configuration, status(configuration, path)); } private static FileStatus status(Configuration configuration, Path path) throws IOException { return path.getFileSystem(configuration).getFileStatus(path); } /** * this always returns the row groups * @param configuration * @param pathStatus * @return * @throws IOException */ @Deprecated public static List
readFooters(Configuration configuration, FileStatus pathStatus) throws IOException { return readFooters(configuration, pathStatus, false); } /** * Read the footers of all the files under that path (recursively) * using summary files if possible * @param configuration the configuration to access the FS * @param fileStatus the root dir * @return all the footers * @throws IOException */ public static List
readFooters(Configuration configuration, FileStatus pathStatus, boolean skipRowGroups) throws IOException { List files = listFiles(configuration, pathStatus); return readAllFootersInParallelUsingSummaryFiles(configuration, files, skipRowGroups); } private static List listFiles(Configuration conf, FileStatus fileStatus) throws IOException { if (fileStatus.isDir()) { FileSystem fs = fileStatus.getPath().getFileSystem(conf); FileStatus[] list = fs.listStatus(fileStatus.getPath(), new PathFilter() { @Override public boolean accept(Path p) { return !p.getName().startsWith("_") && !p.getName().startsWith("."); } }); List result = new ArrayList(); for (FileStatus sub : list) { result.addAll(listFiles(conf, sub)); } return result; } else { return Arrays.asList(fileStatus); } } /** * Specifically reads a given summary file * @param configuration * @param summaryStatus * @return the metadata translated for each file * @throws IOException */ public static List
readSummaryFile(Configuration configuration, FileStatus summaryStatus) throws IOException { final Path parent = summaryStatus.getPath().getParent(); ParquetMetadata mergedFooters = readFooter(configuration, summaryStatus, filter(false)); return footersFromSummaryFile(parent, mergedFooters); } static ParquetMetadata readSummaryMetadata(Configuration configuration, Path basePath, boolean skipRowGroups) throws IOException { Path metadataFile = new Path(basePath, PARQUET_METADATA_FILE); Path commonMetaDataFile = new Path(basePath, PARQUET_COMMON_METADATA_FILE); FileSystem fileSystem = basePath.getFileSystem(configuration); if (skipRowGroups && fileSystem.exists(commonMetaDataFile)) { // reading the summary file that does not contain the row groups if (Log.INFO) LOG.info("reading summary file: " + commonMetaDataFile); return readFooter(configuration, commonMetaDataFile, filter(skipRowGroups)); } else if (fileSystem.exists(metadataFile)) { if (Log.INFO) LOG.info("reading summary file: " + metadataFile); return readFooter(configuration, metadataFile, filter(skipRowGroups)); } else { return null; } } static List
footersFromSummaryFile(final Path parent, ParquetMetadata mergedFooters) { Map footers = new HashMap(); List blocks = mergedFooters.getBlocks(); for (BlockMetaData block : blocks) { String path = block.getPath(); Path fullPath = new Path(parent, path); ParquetMetadata current = footers.get(fullPath); if (current == null) { current = new ParquetMetadata(mergedFooters.getFileMetaData(), new ArrayList()); footers.put(fullPath, current); } current.getBlocks().add(block); } List
result = new ArrayList
(); for (Entry entry : footers.entrySet()) { result.add(new Footer(entry.getKey(), entry.getValue())); } return result; } /** * Reads the meta data block in the footer of the file * @param configuration * @param file the parquet File * @return the metadata blocks in the footer * @throws IOException if an error occurs while reading the file */ @Deprecated public static final ParquetMetadata readFooter(Configuration configuration, Path file) throws IOException { return readFooter(configuration, file, NO_FILTER); } /** * Reads the meta data in the footer of the file. * Skipping row groups (or not) based on the provided filter * @param configuration * @param file the Parquet File * @param filter the filter to apply to row groups * @return the metadata with row groups filtered. * @throws IOException if an error occurs while reading the file */ public static ParquetMetadata readFooter(Configuration configuration, Path file, MetadataFilter filter) throws IOException { FileSystem fileSystem = file.getFileSystem(configuration); return readFooter(configuration, fileSystem.getFileStatus(file), filter); } /** * @deprecated use {@link ParquetFileReader#readFooter(Configuration, FileStatus, MetadataFilter)} */ @Deprecated public static final ParquetMetadata readFooter(Configuration configuration, FileStatus file) throws IOException { return readFooter(configuration, file, NO_FILTER); } /** * Reads the meta data block in the footer of the file * @param configuration * @param file the parquet File * @param filter the filter to apply to row groups * @return the metadata blocks in the footer * @throws IOException if an error occurs while reading the file */ public static final ParquetMetadata readFooter(Configuration configuration, FileStatus file, MetadataFilter filter) throws IOException { FileSystem fileSystem = file.getPath().getFileSystem(configuration); FSDataInputStream f = fileSystem.open(file.getPath()); try { long l = file.getLen(); if (Log.DEBUG) LOG.debug("File length " + l); int FOOTER_LENGTH_SIZE = 4; if (l < MAGIC.length + FOOTER_LENGTH_SIZE + MAGIC.length) { // MAGIC + data + footer + footerIndex + MAGIC throw new RuntimeException(file.getPath() + " is not a Parquet file (too small)"); } long footerLengthIndex = l - FOOTER_LENGTH_SIZE - MAGIC.length; if (Log.DEBUG) LOG.debug("reading footer index at " + footerLengthIndex); f.seek(footerLengthIndex); int footerLength = readIntLittleEndian(f); byte[] magic = new byte[MAGIC.length]; f.readFully(magic); if (!Arrays.equals(MAGIC, magic)) { throw new RuntimeException(file.getPath() + " is not a Parquet file. expected magic number at tail " + Arrays.toString(MAGIC) + " but found " + Arrays.toString(magic)); } long footerIndex = footerLengthIndex - footerLength; if (Log.DEBUG) LOG.debug("read footer length: " + footerLength + ", footer index: " + footerIndex); if (footerIndex < MAGIC.length || footerIndex >= footerLengthIndex) { throw new RuntimeException("corrupted file: the footer index is not within the file"); } f.seek(footerIndex); return parquetMetadataConverter.readParquetMetadata(f, filter); } finally { f.close(); } } private final CodecFactory codecFactory; private final List blocks; private final FSDataInputStream f; private final Path filePath; private int currentBlock = 0; private final Map paths = new HashMap(); /** * @param f the Parquet file (will be opened for read in this constructor) * @param blocks the blocks to read * @param colums the columns to read (their path) * @param codecClassName the codec used to compress the blocks * @throws IOException if the file can not be opened */ public ParquetFileReader(Configuration configuration, Path filePath, List blocks, List columns) throws IOException { this.filePath = filePath; FileSystem fs = filePath.getFileSystem(configuration); this.f = fs.open(filePath); this.blocks = blocks; for (ColumnDescriptor col : columns) { paths.put(ColumnPath.get(col.getPath()), col); } this.codecFactory = new CodecFactory(configuration); } /** * Reads all the columns requested from the row group at the current file position. * @throws IOException if an error occurs while reading * @return the PageReadStore which can provide PageReaders for each column. */ public PageReadStore readNextRowGroup() throws IOException { if (currentBlock == blocks.size()) { return null; } BlockMetaData block = blocks.get(currentBlock); if (block.getRowCount() == 0) { throw new RuntimeException("Illegal row group of 0 rows"); } ColumnChunkPageReadStore columnChunkPageReadStore = new ColumnChunkPageReadStore(block.getRowCount()); // prepare the list of consecutive chunks to read them in one scan List allChunks = new ArrayList(); ConsecutiveChunkList currentChunks = null; for (ColumnChunkMetaData mc : block.getColumns()) { ColumnPath pathKey = mc.getPath(); BenchmarkCounter.incrementTotalBytes(mc.getTotalSize()); ColumnDescriptor columnDescriptor = paths.get(pathKey); if (columnDescriptor != null) { long startingPos = mc.getStartingPos(); // first chunk or not consecutive => new list if (currentChunks == null || currentChunks.endPos() != startingPos) { currentChunks = new ConsecutiveChunkList(startingPos); allChunks.add(currentChunks); } currentChunks.addChunk(new ChunkDescriptor(columnDescriptor, mc, startingPos, (int)mc.getTotalSize())); } } // actually read all the chunks for (ConsecutiveChunkList consecutiveChunks : allChunks) { final List chunks = consecutiveChunks.readAll(f); for (Chunk chunk : chunks) { columnChunkPageReadStore.addColumn(chunk.descriptor.col, chunk.readAllPages()); } } ++currentBlock; return columnChunkPageReadStore; } @Override public void close() throws IOException { f.close(); this.codecFactory.release(); } /** * The data for a column chunk * * @author Julien Le Dem * */ private class Chunk extends ByteArrayInputStream { private final ChunkDescriptor descriptor; /** * * @param descriptor descriptor for the chunk * @param data contains the chunk data at offset * @param offset where the chunk starts in offset */ public Chunk(ChunkDescriptor descriptor, byte[] data, int offset) { super(data); this.descriptor = descriptor; this.pos = offset; } protected PageHeader readPageHeader() throws IOException { return Util.readPageHeader(this); } /** * Read all of the pages in a given column chunk. * @return the list of pages */ public ColumnChunkPageReader readAllPages() throws IOException { List pagesInChunk = new ArrayList(); DictionaryPage dictionaryPage = null; long valuesCountReadSoFar = 0; while (valuesCountReadSoFar < descriptor.metadata.getValueCount()) { PageHeader pageHeader = readPageHeader(); switch (pageHeader.type) { case DICTIONARY_PAGE: // there is only one dictionary page per column chunk if (dictionaryPage != null) { throw new ParquetDecodingException("more than one dictionary page in column " + descriptor.col); } dictionaryPage = new DictionaryPage( this.readAsBytesInput(pageHeader.compressed_page_size), pageHeader.uncompressed_page_size, pageHeader.dictionary_page_header.num_values, parquetMetadataConverter.getEncoding(pageHeader.dictionary_page_header.encoding) ); break; case DATA_PAGE: pagesInChunk.add( new Page( this.readAsBytesInput(pageHeader.compressed_page_size), pageHeader.data_page_header.num_values, pageHeader.uncompressed_page_size, ParquetMetadataConverter.fromParquetStatistics(pageHeader.data_page_header.statistics, descriptor.col.getType()), parquetMetadataConverter.getEncoding(pageHeader.data_page_header.repetition_level_encoding), parquetMetadataConverter.getEncoding(pageHeader.data_page_header.definition_level_encoding), parquetMetadataConverter.getEncoding(pageHeader.data_page_header.encoding) )); valuesCountReadSoFar += pageHeader.data_page_header.num_values; break; default: if (DEBUG) LOG.debug("skipping page of type " + pageHeader.type + " of size " + pageHeader.compressed_page_size); this.skip(pageHeader.compressed_page_size); break; } } if (valuesCountReadSoFar != descriptor.metadata.getValueCount()) { // Would be nice to have a CorruptParquetFileException or something as a subclass? throw new IOException( "Expected " + descriptor.metadata.getValueCount() + " values in column chunk at " + filePath + " offset " + descriptor.metadata.getFirstDataPageOffset() + " but got " + valuesCountReadSoFar + " values instead over " + pagesInChunk.size() + " pages ending at file offset " + (descriptor.fileOffset + pos())); } BytesDecompressor decompressor = codecFactory.getDecompressor(descriptor.metadata.getCodec()); return new ColumnChunkPageReader(decompressor, pagesInChunk, dictionaryPage); } /** * @return the current position in the chunk */ public int pos() { return this.pos; } /** * @param size the size of the page * @return the page * @throws IOException */ public BytesInput readAsBytesInput(int size) throws IOException { final BytesInput r = BytesInput.from(this.buf, this.pos, size); this.pos += size; return r; } } /** * deals with a now fixed bug where compressedLength was missing a few bytes. * * @author Julien Le Dem * */ private class WorkaroundChunk extends Chunk { private final FSDataInputStream f; /** * @param descriptor the descriptor of the chunk * @param data contains the data of the chunk at offset * @param offset where the chunk starts in data * @param f the file stream positioned at the end of this chunk */ private WorkaroundChunk(ChunkDescriptor descriptor, byte[] data, int offset, FSDataInputStream f) { super(descriptor, data, offset); this.f = f; } protected PageHeader readPageHeader() throws IOException { PageHeader pageHeader; int initialPos = this.pos; try { pageHeader = Util.readPageHeader(this); } catch (IOException e) { // this is to workaround a bug where the compressedLength // of the chunk is missing the size of the header of the dictionary // to allow reading older files (using dictionary) we need this. // usually 13 to 19 bytes are missing // if the last page is smaller than this, the page header itself is truncated in the buffer. this.pos = initialPos; // resetting the buffer to the position before we got the error LOG.info("completing the column chunk to read the page header"); pageHeader = Util.readPageHeader(new SequenceInputStream(this, f)); // trying again from the buffer + remainder of the stream. } return pageHeader; } public BytesInput readAsBytesInput(int size) throws IOException { if (pos + size > count) { // this is to workaround a bug where the compressedLength // of the chunk is missing the size of the header of the dictionary // to allow reading older files (using dictionary) we need this. // usually 13 to 19 bytes are missing int l1 = count - pos; int l2 = size - l1; LOG.info("completed the column chunk with " + l2 + " bytes"); return BytesInput.concat(super.readAsBytesInput(l1), BytesInput.copy(BytesInput.from(f, l2))); } return super.readAsBytesInput(size); } } /** * information needed to read a column chunk */ private static class ChunkDescriptor { private final ColumnDescriptor col; private final ColumnChunkMetaData metadata; private final long fileOffset; private final int size; /** * @param col column this chunk is part of * @param metadata metadata for the column * @param fileOffset offset in the file where this chunk starts * @param size size of the chunk */ private ChunkDescriptor( ColumnDescriptor col, ColumnChunkMetaData metadata, long fileOffset, int size) { super(); this.col = col; this.metadata = metadata; this.fileOffset = fileOffset; this.size = size; } } /** * describes a list of consecutive column chunks to be read at once. * * @author Julien Le Dem */ private class ConsecutiveChunkList { private final long offset; private int length; private final List chunks = new ArrayList(); /** * @param offset where the first chunk starts */ ConsecutiveChunkList(long offset) { this.offset = offset; } /** * adds a chunk to the list. * It must be consecutive to the previous chunk * @param descriptor */ public void addChunk(ChunkDescriptor descriptor) { chunks.add(descriptor); length += descriptor.size; } /** * @param f file to read the chunks from * @return the chunks * @throws IOException */ public List readAll(FSDataInputStream f) throws IOException { List result = new ArrayList(chunks.size()); f.seek(offset); byte[] chunksBytes = new byte[length]; f.readFully(chunksBytes); // report in a counter the data we just scanned BenchmarkCounter.incrementBytesRead(length); int currentChunkOffset = 0; for (int i = 0; i < chunks.size(); i++) { ChunkDescriptor descriptor = chunks.get(i); if (i < chunks.size() - 1) { result.add(new Chunk(descriptor, chunksBytes, currentChunkOffset)); } else { // because of a bug, the last chunk might be larger than descriptor.size result.add(new WorkaroundChunk(descriptor, chunksBytes, currentChunkOffset, f)); } currentChunkOffset += descriptor.size; } return result ; } /** * @return the position following the last byte of these chunks */ public long endPos() { return offset + length; } } }




© 2015 - 2025 Weber Informatics LLC | Privacy Policy