Package com.facebook.presto.spi

Examples of com.facebook.presto.spi.SerializableNativeValue$Deserializer


    }

    @JsonProperty("value")
    public SerializableNativeValue getSerializableNativeValue()
    {
        return new SerializableNativeValue(type, value);
    }
View Full Code Here


    private static final JsonCodec<SimpleRange> codec = JsonCodec.jsonCodec(SimpleRange.class);

    @Test
    public void testRoundTrip()
    {
        SimpleMarker low = new SimpleMarker(true, new SerializableNativeValue(Long.class, new Long(10)));
        SimpleMarker high = new SimpleMarker(false, new SerializableNativeValue(Long.class, new Long(100)));

        SimpleRange expected = new SimpleRange(Optional.fromNullable(low), Optional.fromNullable(high));

        String json = codec.toJson(expected);
        SimpleRange actual = codec.fromJson(json);
View Full Code Here

    private static final JsonCodec<SimpleMarker> codec = JsonCodec.jsonCodec(SimpleMarker.class);

    @Test
    public void testRoundTrip()
    {
        SimpleMarker expected = new SimpleMarker(true, new SerializableNativeValue(Long.class, new Long(10)));
        assertEquals(codec.fromJson(codec.toJson(expected)), expected);

        expected = new SimpleMarker(false, new SerializableNativeValue(Double.class, new Double(10)));
        assertEquals(codec.fromJson(codec.toJson(expected)), expected);

        expected = new SimpleMarker(true, new SerializableNativeValue(Boolean.class, new Boolean(true)));
        assertEquals(codec.fromJson(codec.toJson(expected)), expected);

        expected = new SimpleMarker(true, new SerializableNativeValue(String.class, new String("123")));
        assertEquals(codec.fromJson(codec.toJson(expected)), expected);
    }
View Full Code Here

    private static final JsonCodec<SimpleDomain> codec = JsonCodec.jsonCodec(SimpleDomain.class);

    @Test
    public void testRoundTrip()
    {
        SimpleMarker low = new SimpleMarker(true, new SerializableNativeValue(Long.class, new Long(10)));
        SimpleMarker high = new SimpleMarker(false, new SerializableNativeValue(Long.class, new Long(100)));
        List<SimpleRange> ranges = ImmutableList.of(new SimpleRange(Optional.fromNullable(low), Optional.fromNullable(high)));
        SimpleDomain expected = new SimpleDomain(true, Optional.fromNullable(ranges));

        String json = codec.toJson(expected);
        SimpleDomain actual = codec.fromJson(json);
View Full Code Here

  static public Deserializer getDeserializer(Configuration conf,
      Properties schema) throws MetaException {
    String lib = schema
        .getProperty(org.apache.hadoop.hive.serde.Constants.SERIALIZATION_LIB);
    try {
      Deserializer deserializer = SerDeUtils.lookupDeserializer(lib);
      (deserializer).initialize(conf, schema);
      return deserializer;
    } catch (Exception e) {
      LOG.error("error in initSerDe: " + e.getClass().getName() + " "
          + e.getMessage());
View Full Code Here

    String tableName = String.valueOf(tblProps.getProperty("name"));
    String partName = String.valueOf(partSpec);
    // HiveConf.setVar(hconf, HiveConf.ConfVars.HIVETABLENAME, tableName);
    // HiveConf.setVar(hconf, HiveConf.ConfVars.HIVEPARTITIONNAME, partName);
    Deserializer deserializer = (Deserializer) sdclass.newInstance();
    deserializer.initialize(hconf, tblProps);
    StructObjectInspector rawRowObjectInspector = (StructObjectInspector) deserializer
        .getObjectInspector();

    MapOpCtx opCtx = null;
    // Next check if this table has partitions and if so
    // get the list of partition names as well as allocate
View Full Code Here

  /**
   * Check if the given serde is valid.
   */
  private void validateSerDe(String serdeName) throws HiveException {
    try {
      Deserializer d = SerDeUtils.lookupDeserializer(serdeName);
      if (d != null) {
        LOG.debug("Found class for " + serdeName);
      }
    } catch (SerDeException e) {
      throw new HiveException("Cannot validate serde: " + serdeName, e);
View Full Code Here

    String lib = table.getSd().getSerdeInfo().getSerializationLib();
    if (lib == null) {
      return null;
    }
    try {
      Deserializer deserializer = SerDeUtils.lookupDeserializer(lib);
      deserializer.initialize(conf, MetaStoreUtils.getSchema(table));
      return deserializer;
    } catch (RuntimeException e) {
      throw e;
    } catch (Exception e) {
      LOG.error("error in initSerDe: " + e.getClass().getName() + " "
View Full Code Here

  static public Deserializer getDeserializer(Configuration conf,
      org.apache.hadoop.hive.metastore.api.Partition part,
      org.apache.hadoop.hive.metastore.api.Table table) throws MetaException {
    String lib = part.getSd().getSerdeInfo().getSerializationLib();
    try {
      Deserializer deserializer = SerDeUtils.lookupDeserializer(lib);
      deserializer.initialize(conf, MetaStoreUtils.getSchema(part, table));
      return deserializer;
    } catch (RuntimeException e) {
      throw e;
    } catch (Exception e) {
      LOG.error("error in initSerDe: " + e.getClass().getName() + " "
View Full Code Here

        tbl.getSd().getSerdeInfo().getSerializationLib());
      if (!getColsFromSerDe) {
        return tbl.getSd().getCols();
      } else {
        try {
          Deserializer s = MetaStoreUtils.getDeserializer(hiveConf, tbl);
          return MetaStoreUtils.getFieldsFromDeserializer(tableName, s);
        } catch (SerDeException e) {
          StringUtils.stringifyException(e);
          throw new MetaException(e.getMessage());
        }
View Full Code Here

TOP

Related Classes of com.facebook.presto.spi.SerializableNativeValue$Deserializer

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.