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

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


        {
          oprot.writeI32(struct.stageCounters.size());
          for (Map.Entry<String, Long> _iter87 : struct.stageCounters.entrySet())
          {
            oprot.writeString(_iter87.getKey());
            oprot.writeI64(_iter87.getValue());
          }
        }
      }
      if (struct.isSetTaskList()) {
        {
View Full Code Here


        {
          oprot.writeI32(struct.queryCounters.size());
          for (Map.Entry<String, Long> _iter115 : struct.queryCounters.entrySet())
          {
            oprot.writeString(_iter115.getKey());
            oprot.writeI64(_iter115.getValue());
          }
        }
      }
      if (struct.isSetStageGraph()) {
        struct.stageGraph.write(oprot);
View Full Code Here

        {
          oprot.writeI32(struct.operatorCounters.size());
          for (Map.Entry<String, Long> _iter35 : struct.operatorCounters.entrySet())
          {
            oprot.writeString(_iter35.getKey());
            oprot.writeI64(_iter35.getValue());
          }
        }
      }
      if (struct.isSetDone()) {
        oprot.writeBool(struct.done);
View Full Code Here

        {
          oprot.writeI32(struct.taskCounters.size());
          for (Map.Entry<String, Long> _iter59 : struct.taskCounters.entrySet())
          {
            oprot.writeString(_iter59.getKey());
            oprot.writeI64(_iter59.getValue());
          }
        }
      }
      if (struct.isSetOperatorGraph()) {
        struct.operatorGraph.write(oprot);
View Full Code Here

      }
      if (struct.isSetMy_32bit_int()) {
        oprot.writeI32(struct.my_32bit_int);
      }
      if (struct.isSetMy_64bit_int()) {
        oprot.writeI64(struct.my_64bit_int);
      }
      if (struct.isSetMy_double()) {
        oprot.writeDouble(struct.my_double);
      }
      if (struct.isSetMy_string()) {
View Full Code Here

  private static class TxnInfoTupleScheme extends TupleScheme<TxnInfo> {

    @Override
    public void write(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, TxnInfo struct) throws com.facebook.presto.hive.shaded.org.apache.thrift.TException {
      TTupleProtocol oprot = (TTupleProtocol) prot;
      oprot.writeI64(struct.id);
      oprot.writeI32(struct.state.getValue());
      oprot.writeString(struct.user);
      oprot.writeString(struct.hostname);
    }
View Full Code Here

      TTupleProtocol oprot = (TTupleProtocol) prot;
      {
        oprot.writeI32(struct.aborted.size());
        for (long _iter426 : struct.aborted)
        {
          oprot.writeI64(_iter426);
        }
      }
      {
        oprot.writeI32(struct.nosuch.size());
        for (long _iter427 : struct.nosuch)
View Full Code Here

      }
      {
        oprot.writeI32(struct.nosuch.size());
        for (long _iter427 : struct.nosuch)
        {
          oprot.writeI64(_iter427);
        }
      }
    }

    @Override
View Full Code Here

  private static class CommitTxnRequestTupleScheme extends TupleScheme<CommitTxnRequest> {

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

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

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

    @Override
    public void read(com.facebook.presto.hive.shaded.org.apache.thrift.protocol.TProtocol prot, DoubleColumnStatsData 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.