Package com.facebook.presto.hive.shaded.org.apache.thrift.protocol

Examples of com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TTupleProtocol.writeI64()


      oprot.writeString(struct.tablename);
      oprot.writeString(struct.partitionname);
      oprot.writeI32(struct.type.getValue());
      oprot.writeString(struct.state);
      oprot.writeString(struct.workerid);
      oprot.writeI64(struct.start);
      oprot.writeString(struct.runAs);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, ShowCompactResponseElement struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
View Full Code Here


      oprot.writeBitSet(optionals, 2);
      if (struct.isSetPartName()) {
        oprot.writeString(struct.partName);
      }
      if (struct.isSetLastAnalyzed()) {
        oprot.writeI64(struct.lastAnalyzed);
      }
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, ColumnStatisticsDesc struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
View Full Code Here

  private static class GetOpenTxnsResponseTupleScheme extends TupleScheme<GetOpenTxnsResponse> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, GetOpenTxnsResponse struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.txn_high_water_mark);
      {
        oprot.writeI32(struct.open_txns.size());
        for (long _iter390 : struct.open_txns)
        {
          oprot.writeI64(_iter390);
View Full Code Here

      oprot.writeI64(struct.txn_high_water_mark);
      {
        oprot.writeI32(struct.open_txns.size());
        for (long _iter390 : struct.open_txns)
        {
          oprot.writeI64(_iter390);
        }
      }
    }

    @Override
View Full Code Here

  private static class StringColumnStatsDataTupleScheme extends TupleScheme<StringColumnStatsData> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, StringColumnStatsData struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.maxColLen);
      oprot.writeDouble(struct.avgColLen);
      oprot.writeI64(struct.numNulls);
      oprot.writeI64(struct.numDVs);
    }
View Full Code Here

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, StringColumnStatsData struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.maxColLen);
      oprot.writeDouble(struct.avgColLen);
      oprot.writeI64(struct.numNulls);
      oprot.writeI64(struct.numDVs);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, StringColumnStatsData struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
View Full Code Here

    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, StringColumnStatsData struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.maxColLen);
      oprot.writeDouble(struct.avgColLen);
      oprot.writeI64(struct.numNulls);
      oprot.writeI64(struct.numDVs);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, StringColumnStatsData struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol iprot = (TTupleProtocol) prot;
View Full Code Here

  private static class UnlockRequestTupleScheme extends TupleScheme<UnlockRequest> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, UnlockRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.lockid);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, UnlockRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol iprot = (TTupleProtocol) prot;
View Full Code Here

  private static class CheckLockRequestTupleScheme extends TupleScheme<CheckLockRequest> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, CheckLockRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.lockid);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, CheckLockRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol iprot = (TTupleProtocol) prot;
View Full Code Here

  private static class HeartbeatTxnRangeRequestTupleScheme extends TupleScheme<HeartbeatTxnRangeRequest> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.min);
      oprot.writeI64(struct.max);
    }

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeRequest struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
View Full Code Here

TOP
Copyright © 2018 www.massapi.com. 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.