Interface HiveMapper

All Superinterfaces:
Serializable
All Known Implementing Classes:
DelimitedRecordHiveMapper, JsonRecordHiveMapper

public interface HiveMapper extends Serializable
Maps a org.apache.storm.tuple.Tupe object to a row in an Hive table.
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hive.hcatalog.streaming.RecordWriter
    createRecordWriter(org.apache.hive.hcatalog.streaming.HiveEndPoint endPoint)
    Given a endPoint, returns a RecordWriter with columnNames.
    Given a TridetnTuple, return a hive partition values list.
    Given a tuple, return a hive partition values list.
    byte[]
    Given a TridentTuple, maps to a HiveRecord based on columnFields.
    byte[]
    Given a tuple, maps to a HiveRecord based on columnFields.
    void
    write(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch, Tuple tuple)
     
  • Method Details

    • createRecordWriter

      org.apache.hive.hcatalog.streaming.RecordWriter createRecordWriter(org.apache.hive.hcatalog.streaming.HiveEndPoint endPoint) throws org.apache.hive.hcatalog.streaming.StreamingException, IOException, ClassNotFoundException
      Given a endPoint, returns a RecordWriter with columnNames.
      Throws:
      org.apache.hive.hcatalog.streaming.StreamingException
      IOException
      ClassNotFoundException
    • write

      void write(org.apache.hive.hcatalog.streaming.TransactionBatch txnBatch, Tuple tuple) throws org.apache.hive.hcatalog.streaming.StreamingException, IOException, InterruptedException
      Throws:
      org.apache.hive.hcatalog.streaming.StreamingException
      IOException
      InterruptedException
    • mapPartitions

      List<String> mapPartitions(Tuple tuple)
      Given a tuple, return a hive partition values list.
    • mapPartitions

      List<String> mapPartitions(TridentTuple tuple)
      Given a TridetnTuple, return a hive partition values list.
    • mapRecord

      byte[] mapRecord(Tuple tuple)
      Given a tuple, maps to a HiveRecord based on columnFields.
    • mapRecord

      byte[] mapRecord(TridentTuple tuple)
      Given a TridentTuple, maps to a HiveRecord based on columnFields.