You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by se...@apache.org on 2016/05/09 19:42:46 UTC

[1/5] hive git commit: HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)

Repository: hive
Updated Branches:
  refs/heads/master c204dd7fb -> 10c07d6ec


http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php b/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
index 0e7b745..2172cb7 100644
--- a/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
+++ b/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
@@ -1146,11 +1146,6 @@ interface ThriftHiveMetastoreIf extends \FacebookServiceIf {
    * @return \metastore\CacheFileMetadataResult
    */
   public function cache_file_metadata(\metastore\CacheFileMetadataRequest $req);
-  /**
-   * @param \metastore\GetChangeVersionRequest $req
-   * @return \metastore\GetChangeVersionResult
-   */
-  public function get_change_version(\metastore\GetChangeVersionRequest $req);
 }
 
 class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metastore\ThriftHiveMetastoreIf {
@@ -9470,57 +9465,6 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("cache_file_metadata failed: unknown result");
   }
 
-  public function get_change_version(\metastore\GetChangeVersionRequest $req)
-  {
-    $this->send_get_change_version($req);
-    return $this->recv_get_change_version();
-  }
-
-  public function send_get_change_version(\metastore\GetChangeVersionRequest $req)
-  {
-    $args = new \metastore\ThriftHiveMetastore_get_change_version_args();
-    $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
-    if ($bin_accel)
-    {
-      thrift_protocol_write_binary($this->output_, 'get_change_version', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
-    }
-    else
-    {
-      $this->output_->writeMessageBegin('get_change_version', TMessageType::CALL, $this->seqid_);
-      $args->write($this->output_);
-      $this->output_->writeMessageEnd();
-      $this->output_->getTransport()->flush();
-    }
-  }
-
-  public function recv_get_change_version()
-  {
-    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
-    if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_change_version_result', $this->input_->isStrictRead());
-    else
-    {
-      $rseqid = 0;
-      $fname = null;
-      $mtype = 0;
-
-      $this->input_->readMessageBegin($fname, $mtype, $rseqid);
-      if ($mtype == TMessageType::EXCEPTION) {
-        $x = new TApplicationException();
-        $x->read($this->input_);
-        $this->input_->readMessageEnd();
-        throw $x;
-      }
-      $result = new \metastore\ThriftHiveMetastore_get_change_version_result();
-      $result->read($this->input_);
-      $this->input_->readMessageEnd();
-    }
-    if ($result->success !== null) {
-      return $result->success;
-    }
-    throw new \Exception("get_change_version failed: unknown result");
-  }
-
 }
 
 // HELPER FUNCTIONS AND STRUCTURES
@@ -43376,164 +43320,4 @@ class ThriftHiveMetastore_cache_file_metadata_result {
 
 }
 
-class ThriftHiveMetastore_get_change_version_args {
-  static $_TSPEC;
-
-  /**
-   * @var \metastore\GetChangeVersionRequest
-   */
-  public $req = null;
-
-  public function __construct($vals=null) {
-    if (!isset(self::$_TSPEC)) {
-      self::$_TSPEC = array(
-        1 => array(
-          'var' => 'req',
-          'type' => TType::STRUCT,
-          'class' => '\metastore\GetChangeVersionRequest',
-          ),
-        );
-    }
-    if (is_array($vals)) {
-      if (isset($vals['req'])) {
-        $this->req = $vals['req'];
-      }
-    }
-  }
-
-  public function getName() {
-    return 'ThriftHiveMetastore_get_change_version_args';
-  }
-
-  public function read($input)
-  {
-    $xfer = 0;
-    $fname = null;
-    $ftype = 0;
-    $fid = 0;
-    $xfer += $input->readStructBegin($fname);
-    while (true)
-    {
-      $xfer += $input->readFieldBegin($fname, $ftype, $fid);
-      if ($ftype == TType::STOP) {
-        break;
-      }
-      switch ($fid)
-      {
-        case 1:
-          if ($ftype == TType::STRUCT) {
-            $this->req = new \metastore\GetChangeVersionRequest();
-            $xfer += $this->req->read($input);
-          } else {
-            $xfer += $input->skip($ftype);
-          }
-          break;
-        default:
-          $xfer += $input->skip($ftype);
-          break;
-      }
-      $xfer += $input->readFieldEnd();
-    }
-    $xfer += $input->readStructEnd();
-    return $xfer;
-  }
-
-  public function write($output) {
-    $xfer = 0;
-    $xfer += $output->writeStructBegin('ThriftHiveMetastore_get_change_version_args');
-    if ($this->req !== null) {
-      if (!is_object($this->req)) {
-        throw new TProtocolException('Bad type in structure.', TProtocolException::INVALID_DATA);
-      }
-      $xfer += $output->writeFieldBegin('req', TType::STRUCT, 1);
-      $xfer += $this->req->write($output);
-      $xfer += $output->writeFieldEnd();
-    }
-    $xfer += $output->writeFieldStop();
-    $xfer += $output->writeStructEnd();
-    return $xfer;
-  }
-
-}
-
-class ThriftHiveMetastore_get_change_version_result {
-  static $_TSPEC;
-
-  /**
-   * @var \metastore\GetChangeVersionResult
-   */
-  public $success = null;
-
-  public function __construct($vals=null) {
-    if (!isset(self::$_TSPEC)) {
-      self::$_TSPEC = array(
-        0 => array(
-          'var' => 'success',
-          'type' => TType::STRUCT,
-          'class' => '\metastore\GetChangeVersionResult',
-          ),
-        );
-    }
-    if (is_array($vals)) {
-      if (isset($vals['success'])) {
-        $this->success = $vals['success'];
-      }
-    }
-  }
-
-  public function getName() {
-    return 'ThriftHiveMetastore_get_change_version_result';
-  }
-
-  public function read($input)
-  {
-    $xfer = 0;
-    $fname = null;
-    $ftype = 0;
-    $fid = 0;
-    $xfer += $input->readStructBegin($fname);
-    while (true)
-    {
-      $xfer += $input->readFieldBegin($fname, $ftype, $fid);
-      if ($ftype == TType::STOP) {
-        break;
-      }
-      switch ($fid)
-      {
-        case 0:
-          if ($ftype == TType::STRUCT) {
-            $this->success = new \metastore\GetChangeVersionResult();
-            $xfer += $this->success->read($input);
-          } else {
-            $xfer += $input->skip($ftype);
-          }
-          break;
-        default:
-          $xfer += $input->skip($ftype);
-          break;
-      }
-      $xfer += $input->readFieldEnd();
-    }
-    $xfer += $input->readStructEnd();
-    return $xfer;
-  }
-
-  public function write($output) {
-    $xfer = 0;
-    $xfer += $output->writeStructBegin('ThriftHiveMetastore_get_change_version_result');
-    if ($this->success !== null) {
-      if (!is_object($this->success)) {
-        throw new TProtocolException('Bad type in structure.', TProtocolException::INVALID_DATA);
-      }
-      $xfer += $output->writeFieldBegin('success', TType::STRUCT, 0);
-      $xfer += $this->success->write($output);
-      $xfer += $output->writeFieldEnd();
-    }
-    $xfer += $output->writeFieldStop();
-    $xfer += $output->writeStructEnd();
-    return $xfer;
-  }
-
-}
-
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-php/metastore/Types.php
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-php/metastore/Types.php b/metastore/src/gen/thrift/gen-php/metastore/Types.php
index a8a7db9..f985954 100644
--- a/metastore/src/gen/thrift/gen-php/metastore/Types.php
+++ b/metastore/src/gen/thrift/gen-php/metastore/Types.php
@@ -15670,156 +15670,6 @@ class FireEventResponse {
 
 }
 
-class GetChangeVersionRequest {
-  static $_TSPEC;
-
-  /**
-   * @var string
-   */
-  public $topic = null;
-
-  public function __construct($vals=null) {
-    if (!isset(self::$_TSPEC)) {
-      self::$_TSPEC = array(
-        1 => array(
-          'var' => 'topic',
-          'type' => TType::STRING,
-          ),
-        );
-    }
-    if (is_array($vals)) {
-      if (isset($vals['topic'])) {
-        $this->topic = $vals['topic'];
-      }
-    }
-  }
-
-  public function getName() {
-    return 'GetChangeVersionRequest';
-  }
-
-  public function read($input)
-  {
-    $xfer = 0;
-    $fname = null;
-    $ftype = 0;
-    $fid = 0;
-    $xfer += $input->readStructBegin($fname);
-    while (true)
-    {
-      $xfer += $input->readFieldBegin($fname, $ftype, $fid);
-      if ($ftype == TType::STOP) {
-        break;
-      }
-      switch ($fid)
-      {
-        case 1:
-          if ($ftype == TType::STRING) {
-            $xfer += $input->readString($this->topic);
-          } else {
-            $xfer += $input->skip($ftype);
-          }
-          break;
-        default:
-          $xfer += $input->skip($ftype);
-          break;
-      }
-      $xfer += $input->readFieldEnd();
-    }
-    $xfer += $input->readStructEnd();
-    return $xfer;
-  }
-
-  public function write($output) {
-    $xfer = 0;
-    $xfer += $output->writeStructBegin('GetChangeVersionRequest');
-    if ($this->topic !== null) {
-      $xfer += $output->writeFieldBegin('topic', TType::STRING, 1);
-      $xfer += $output->writeString($this->topic);
-      $xfer += $output->writeFieldEnd();
-    }
-    $xfer += $output->writeFieldStop();
-    $xfer += $output->writeStructEnd();
-    return $xfer;
-  }
-
-}
-
-class GetChangeVersionResult {
-  static $_TSPEC;
-
-  /**
-   * @var int
-   */
-  public $version = null;
-
-  public function __construct($vals=null) {
-    if (!isset(self::$_TSPEC)) {
-      self::$_TSPEC = array(
-        1 => array(
-          'var' => 'version',
-          'type' => TType::I64,
-          ),
-        );
-    }
-    if (is_array($vals)) {
-      if (isset($vals['version'])) {
-        $this->version = $vals['version'];
-      }
-    }
-  }
-
-  public function getName() {
-    return 'GetChangeVersionResult';
-  }
-
-  public function read($input)
-  {
-    $xfer = 0;
-    $fname = null;
-    $ftype = 0;
-    $fid = 0;
-    $xfer += $input->readStructBegin($fname);
-    while (true)
-    {
-      $xfer += $input->readFieldBegin($fname, $ftype, $fid);
-      if ($ftype == TType::STOP) {
-        break;
-      }
-      switch ($fid)
-      {
-        case 1:
-          if ($ftype == TType::I64) {
-            $xfer += $input->readI64($this->version);
-          } else {
-            $xfer += $input->skip($ftype);
-          }
-          break;
-        default:
-          $xfer += $input->skip($ftype);
-          break;
-      }
-      $xfer += $input->readFieldEnd();
-    }
-    $xfer += $input->readStructEnd();
-    return $xfer;
-  }
-
-  public function write($output) {
-    $xfer = 0;
-    $xfer += $output->writeStructBegin('GetChangeVersionResult');
-    if ($this->version !== null) {
-      $xfer += $output->writeFieldBegin('version', TType::I64, 1);
-      $xfer += $output->writeI64($this->version);
-      $xfer += $output->writeFieldEnd();
-    }
-    $xfer += $output->writeFieldStop();
-    $xfer += $output->writeStructEnd();
-    return $xfer;
-  }
-
-}
-
 class MetadataPpdResult {
   static $_TSPEC;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
index 5323d9f..e124cd0 100755
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
@@ -170,7 +170,6 @@ if len(sys.argv) <= 1 or sys.argv[1] == '--help':
   print('  PutFileMetadataResult put_file_metadata(PutFileMetadataRequest req)')
   print('  ClearFileMetadataResult clear_file_metadata(ClearFileMetadataRequest req)')
   print('  CacheFileMetadataResult cache_file_metadata(CacheFileMetadataRequest req)')
-  print('  GetChangeVersionResult get_change_version(GetChangeVersionRequest req)')
   print('  string getName()')
   print('  string getVersion()')
   print('  fb_status getStatus()')
@@ -1116,12 +1115,6 @@ elif cmd == 'cache_file_metadata':
     sys.exit(1)
   pp.pprint(client.cache_file_metadata(eval(args[0]),))
 
-elif cmd == 'get_change_version':
-  if len(args) != 1:
-    print('get_change_version requires 1 args')
-    sys.exit(1)
-  pp.pprint(client.get_change_version(eval(args[0]),))
-
 elif cmd == 'getName':
   if len(args) != 0:
     print('getName requires 0 args')

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
index bf8d383..4f522c9 100644
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
@@ -1179,13 +1179,6 @@ class Iface(fb303.FacebookService.Iface):
     """
     pass
 
-  def get_change_version(self, req):
-    """
-    Parameters:
-     - req
-    """
-    pass
-
 
 class Client(fb303.FacebookService.Client, Iface):
   """
@@ -6485,37 +6478,6 @@ class Client(fb303.FacebookService.Client, Iface):
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "cache_file_metadata failed: unknown result")
 
-  def get_change_version(self, req):
-    """
-    Parameters:
-     - req
-    """
-    self.send_get_change_version(req)
-    return self.recv_get_change_version()
-
-  def send_get_change_version(self, req):
-    self._oprot.writeMessageBegin('get_change_version', TMessageType.CALL, self._seqid)
-    args = get_change_version_args()
-    args.req = req
-    args.write(self._oprot)
-    self._oprot.writeMessageEnd()
-    self._oprot.trans.flush()
-
-  def recv_get_change_version(self):
-    iprot = self._iprot
-    (fname, mtype, rseqid) = iprot.readMessageBegin()
-    if mtype == TMessageType.EXCEPTION:
-      x = TApplicationException()
-      x.read(iprot)
-      iprot.readMessageEnd()
-      raise x
-    result = get_change_version_result()
-    result.read(iprot)
-    iprot.readMessageEnd()
-    if result.success is not None:
-      return result.success
-    raise TApplicationException(TApplicationException.MISSING_RESULT, "get_change_version failed: unknown result")
-
 
 class Processor(fb303.FacebookService.Processor, Iface, TProcessor):
   def __init__(self, handler):
@@ -6666,7 +6628,6 @@ class Processor(fb303.FacebookService.Processor, Iface, TProcessor):
     self._processMap["put_file_metadata"] = Processor.process_put_file_metadata
     self._processMap["clear_file_metadata"] = Processor.process_clear_file_metadata
     self._processMap["cache_file_metadata"] = Processor.process_cache_file_metadata
-    self._processMap["get_change_version"] = Processor.process_get_change_version
 
   def process(self, iprot, oprot):
     (name, type, seqid) = iprot.readMessageBegin()
@@ -10258,25 +10219,6 @@ class Processor(fb303.FacebookService.Processor, Iface, TProcessor):
     oprot.writeMessageEnd()
     oprot.trans.flush()
 
-  def process_get_change_version(self, seqid, iprot, oprot):
-    args = get_change_version_args()
-    args.read(iprot)
-    iprot.readMessageEnd()
-    result = get_change_version_result()
-    try:
-      result.success = self._handler.get_change_version(args.req)
-      msg_type = TMessageType.REPLY
-    except (TTransport.TTransportException, KeyboardInterrupt, SystemExit):
-      raise
-    except Exception as ex:
-      msg_type = TMessageType.EXCEPTION
-      logging.exception(ex)
-      result = TApplicationException(TApplicationException.INTERNAL_ERROR, 'Internal error')
-    oprot.writeMessageBegin("get_change_version", msg_type, seqid)
-    result.write(oprot)
-    oprot.writeMessageEnd()
-    oprot.trans.flush()
-
 
 # HELPER FUNCTIONS AND STRUCTURES
 
@@ -35154,134 +35096,3 @@ class cache_file_metadata_result:
 
   def __ne__(self, other):
     return not (self == other)
-
-class get_change_version_args:
-  """
-  Attributes:
-   - req
-  """
-
-  thrift_spec = (
-    None, # 0
-    (1, TType.STRUCT, 'req', (GetChangeVersionRequest, GetChangeVersionRequest.thrift_spec), None, ), # 1
-  )
-
-  def __init__(self, req=None,):
-    self.req = req
-
-  def read(self, iprot):
-    if iprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and isinstance(iprot.trans, TTransport.CReadableTransport) and self.thrift_spec is not None and fastbinary is not None:
-      fastbinary.decode_binary(self, iprot.trans, (self.__class__, self.thrift_spec))
-      return
-    iprot.readStructBegin()
-    while True:
-      (fname, ftype, fid) = iprot.readFieldBegin()
-      if ftype == TType.STOP:
-        break
-      if fid == 1:
-        if ftype == TType.STRUCT:
-          self.req = GetChangeVersionRequest()
-          self.req.read(iprot)
-        else:
-          iprot.skip(ftype)
-      else:
-        iprot.skip(ftype)
-      iprot.readFieldEnd()
-    iprot.readStructEnd()
-
-  def write(self, oprot):
-    if oprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and self.thrift_spec is not None and fastbinary is not None:
-      oprot.trans.write(fastbinary.encode_binary(self, (self.__class__, self.thrift_spec)))
-      return
-    oprot.writeStructBegin('get_change_version_args')
-    if self.req is not None:
-      oprot.writeFieldBegin('req', TType.STRUCT, 1)
-      self.req.write(oprot)
-      oprot.writeFieldEnd()
-    oprot.writeFieldStop()
-    oprot.writeStructEnd()
-
-  def validate(self):
-    return
-
-
-  def __hash__(self):
-    value = 17
-    value = (value * 31) ^ hash(self.req)
-    return value
-
-  def __repr__(self):
-    L = ['%s=%r' % (key, value)
-      for key, value in self.__dict__.iteritems()]
-    return '%s(%s)' % (self.__class__.__name__, ', '.join(L))
-
-  def __eq__(self, other):
-    return isinstance(other, self.__class__) and self.__dict__ == other.__dict__
-
-  def __ne__(self, other):
-    return not (self == other)
-
-class get_change_version_result:
-  """
-  Attributes:
-   - success
-  """
-
-  thrift_spec = (
-    (0, TType.STRUCT, 'success', (GetChangeVersionResult, GetChangeVersionResult.thrift_spec), None, ), # 0
-  )
-
-  def __init__(self, success=None,):
-    self.success = success
-
-  def read(self, iprot):
-    if iprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and isinstance(iprot.trans, TTransport.CReadableTransport) and self.thrift_spec is not None and fastbinary is not None:
-      fastbinary.decode_binary(self, iprot.trans, (self.__class__, self.thrift_spec))
-      return
-    iprot.readStructBegin()
-    while True:
-      (fname, ftype, fid) = iprot.readFieldBegin()
-      if ftype == TType.STOP:
-        break
-      if fid == 0:
-        if ftype == TType.STRUCT:
-          self.success = GetChangeVersionResult()
-          self.success.read(iprot)
-        else:
-          iprot.skip(ftype)
-      else:
-        iprot.skip(ftype)
-      iprot.readFieldEnd()
-    iprot.readStructEnd()
-
-  def write(self, oprot):
-    if oprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and self.thrift_spec is not None and fastbinary is not None:
-      oprot.trans.write(fastbinary.encode_binary(self, (self.__class__, self.thrift_spec)))
-      return
-    oprot.writeStructBegin('get_change_version_result')
-    if self.success is not None:
-      oprot.writeFieldBegin('success', TType.STRUCT, 0)
-      self.success.write(oprot)
-      oprot.writeFieldEnd()
-    oprot.writeFieldStop()
-    oprot.writeStructEnd()
-
-  def validate(self):
-    return
-
-
-  def __hash__(self):
-    value = 17
-    value = (value * 31) ^ hash(self.success)
-    return value
-
-  def __repr__(self):
-    L = ['%s=%r' % (key, value)
-      for key, value in self.__dict__.iteritems()]
-    return '%s(%s)' % (self.__class__.__name__, ', '.join(L))
-
-  def __eq__(self, other):
-    return isinstance(other, self.__class__) and self.__dict__ == other.__dict__
-
-  def __ne__(self, other):
-    return not (self == other)

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py b/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
index 8e0cb71..953c97c 100644
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
@@ -10951,140 +10951,6 @@ class FireEventResponse:
   def __ne__(self, other):
     return not (self == other)
 
-class GetChangeVersionRequest:
-  """
-  Attributes:
-   - topic
-  """
-
-  thrift_spec = (
-    None, # 0
-    (1, TType.STRING, 'topic', None, None, ), # 1
-  )
-
-  def __init__(self, topic=None,):
-    self.topic = topic
-
-  def read(self, iprot):
-    if iprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and isinstance(iprot.trans, TTransport.CReadableTransport) and self.thrift_spec is not None and fastbinary is not None:
-      fastbinary.decode_binary(self, iprot.trans, (self.__class__, self.thrift_spec))
-      return
-    iprot.readStructBegin()
-    while True:
-      (fname, ftype, fid) = iprot.readFieldBegin()
-      if ftype == TType.STOP:
-        break
-      if fid == 1:
-        if ftype == TType.STRING:
-          self.topic = iprot.readString()
-        else:
-          iprot.skip(ftype)
-      else:
-        iprot.skip(ftype)
-      iprot.readFieldEnd()
-    iprot.readStructEnd()
-
-  def write(self, oprot):
-    if oprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and self.thrift_spec is not None and fastbinary is not None:
-      oprot.trans.write(fastbinary.encode_binary(self, (self.__class__, self.thrift_spec)))
-      return
-    oprot.writeStructBegin('GetChangeVersionRequest')
-    if self.topic is not None:
-      oprot.writeFieldBegin('topic', TType.STRING, 1)
-      oprot.writeString(self.topic)
-      oprot.writeFieldEnd()
-    oprot.writeFieldStop()
-    oprot.writeStructEnd()
-
-  def validate(self):
-    if self.topic is None:
-      raise TProtocol.TProtocolException(message='Required field topic is unset!')
-    return
-
-
-  def __hash__(self):
-    value = 17
-    value = (value * 31) ^ hash(self.topic)
-    return value
-
-  def __repr__(self):
-    L = ['%s=%r' % (key, value)
-      for key, value in self.__dict__.iteritems()]
-    return '%s(%s)' % (self.__class__.__name__, ', '.join(L))
-
-  def __eq__(self, other):
-    return isinstance(other, self.__class__) and self.__dict__ == other.__dict__
-
-  def __ne__(self, other):
-    return not (self == other)
-
-class GetChangeVersionResult:
-  """
-  Attributes:
-   - version
-  """
-
-  thrift_spec = (
-    None, # 0
-    (1, TType.I64, 'version', None, None, ), # 1
-  )
-
-  def __init__(self, version=None,):
-    self.version = version
-
-  def read(self, iprot):
-    if iprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and isinstance(iprot.trans, TTransport.CReadableTransport) and self.thrift_spec is not None and fastbinary is not None:
-      fastbinary.decode_binary(self, iprot.trans, (self.__class__, self.thrift_spec))
-      return
-    iprot.readStructBegin()
-    while True:
-      (fname, ftype, fid) = iprot.readFieldBegin()
-      if ftype == TType.STOP:
-        break
-      if fid == 1:
-        if ftype == TType.I64:
-          self.version = iprot.readI64()
-        else:
-          iprot.skip(ftype)
-      else:
-        iprot.skip(ftype)
-      iprot.readFieldEnd()
-    iprot.readStructEnd()
-
-  def write(self, oprot):
-    if oprot.__class__ == TBinaryProtocol.TBinaryProtocolAccelerated and self.thrift_spec is not None and fastbinary is not None:
-      oprot.trans.write(fastbinary.encode_binary(self, (self.__class__, self.thrift_spec)))
-      return
-    oprot.writeStructBegin('GetChangeVersionResult')
-    if self.version is not None:
-      oprot.writeFieldBegin('version', TType.I64, 1)
-      oprot.writeI64(self.version)
-      oprot.writeFieldEnd()
-    oprot.writeFieldStop()
-    oprot.writeStructEnd()
-
-  def validate(self):
-    if self.version is None:
-      raise TProtocol.TProtocolException(message='Required field version is unset!')
-    return
-
-
-  def __hash__(self):
-    value = 17
-    value = (value * 31) ^ hash(self.version)
-    return value
-
-  def __repr__(self):
-    L = ['%s=%r' % (key, value)
-      for key, value in self.__dict__.iteritems()]
-    return '%s(%s)' % (self.__class__.__name__, ', '.join(L))
-
-  def __eq__(self, other):
-    return isinstance(other, self.__class__) and self.__dict__ == other.__dict__
-
-  def __ne__(self, other):
-    return not (self == other)
-
 class MetadataPpdResult:
   """
   Attributes:

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb b/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
index 4d3e49d..a5ba4c1 100644
--- a/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
+++ b/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
@@ -2465,40 +2465,6 @@ class FireEventResponse
   ::Thrift::Struct.generate_accessors self
 end
 
-class GetChangeVersionRequest
-  include ::Thrift::Struct, ::Thrift::Struct_Union
-  TOPIC = 1
-
-  FIELDS = {
-    TOPIC => {:type => ::Thrift::Types::STRING, :name => 'topic'}
-  }
-
-  def struct_fields; FIELDS; end
-
-  def validate
-    raise ::Thrift::ProtocolException.new(::Thrift::ProtocolException::UNKNOWN, 'Required field topic is unset!') unless @topic
-  end
-
-  ::Thrift::Struct.generate_accessors self
-end
-
-class GetChangeVersionResult
-  include ::Thrift::Struct, ::Thrift::Struct_Union
-  VERSION = 1
-
-  FIELDS = {
-    VERSION => {:type => ::Thrift::Types::I64, :name => 'version'}
-  }
-
-  def struct_fields; FIELDS; end
-
-  def validate
-    raise ::Thrift::ProtocolException.new(::Thrift::ProtocolException::UNKNOWN, 'Required field version is unset!') unless @version
-  end
-
-  ::Thrift::Struct.generate_accessors self
-end
-
 class MetadataPpdResult
   include ::Thrift::Struct, ::Thrift::Struct_Union
   METADATA = 1

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb b/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
index 61d1832..97bb657 100644
--- a/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
+++ b/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
@@ -2437,21 +2437,6 @@ module ThriftHiveMetastore
       raise ::Thrift::ApplicationException.new(::Thrift::ApplicationException::MISSING_RESULT, 'cache_file_metadata failed: unknown result')
     end
 
-    def get_change_version(req)
-      send_get_change_version(req)
-      return recv_get_change_version()
-    end
-
-    def send_get_change_version(req)
-      send_message('get_change_version', Get_change_version_args, :req => req)
-    end
-
-    def recv_get_change_version()
-      result = receive_message(Get_change_version_result)
-      return result.success unless result.success.nil?
-      raise ::Thrift::ApplicationException.new(::Thrift::ApplicationException::MISSING_RESULT, 'get_change_version failed: unknown result')
-    end
-
   end
 
   class Processor < ::FacebookService::Processor 
@@ -4261,13 +4246,6 @@ module ThriftHiveMetastore
       write_result(result, oprot, 'cache_file_metadata', seqid)
     end
 
-    def process_get_change_version(seqid, iprot, oprot)
-      args = read_args(iprot, Get_change_version_args)
-      result = Get_change_version_result.new()
-      result.success = @handler.get_change_version(args.req)
-      write_result(result, oprot, 'get_change_version', seqid)
-    end
-
   end
 
   # HELPER FUNCTIONS AND STRUCTURES
@@ -9768,37 +9746,5 @@ module ThriftHiveMetastore
     ::Thrift::Struct.generate_accessors self
   end
 
-  class Get_change_version_args
-    include ::Thrift::Struct, ::Thrift::Struct_Union
-    REQ = 1
-
-    FIELDS = {
-      REQ => {:type => ::Thrift::Types::STRUCT, :name => 'req', :class => ::GetChangeVersionRequest}
-    }
-
-    def struct_fields; FIELDS; end
-
-    def validate
-    end
-
-    ::Thrift::Struct.generate_accessors self
-  end
-
-  class Get_change_version_result
-    include ::Thrift::Struct, ::Thrift::Struct_Union
-    SUCCESS = 0
-
-    FIELDS = {
-      SUCCESS => {:type => ::Thrift::Types::STRUCT, :name => 'success', :class => ::GetChangeVersionResult}
-    }
-
-    def struct_fields; FIELDS; end
-
-    def validate
-    end
-
-    ::Thrift::Struct.generate_accessors self
-  end
-
 end
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStore.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStore.java b/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStore.java
index 044b960..5310e2f 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStore.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStore.java
@@ -6190,13 +6190,6 @@ public class HiveMetaStore extends ThriftHiveMetastore {
     }
 
     @Override
-    public GetChangeVersionResult get_change_version(GetChangeVersionRequest req)
-        throws TException {
-      return new GetChangeVersionResult(getMS().getChangeVersion(req.getTopic()));
-    }
-
-
-    @Override
     public PrimaryKeysResponse get_primary_keys(PrimaryKeysRequest request)
       throws MetaException, NoSuchObjectException, TException {
       String db_name = request.getDb_name();
@@ -6250,7 +6243,6 @@ public class HiveMetaStore extends ThriftHiveMetastore {
       }
       return new ForeignKeysResponse(ret);
     }
-
   }
 
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStoreClient.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStoreClient.java b/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStoreClient.java
index 75fea5b..5f2855f 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStoreClient.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/HiveMetaStoreClient.java
@@ -54,7 +54,6 @@ import org.apache.hadoop.hive.metastore.api.FireEventResponse;
 import org.apache.hadoop.hive.metastore.api.ForeignKeysRequest;
 import org.apache.hadoop.hive.metastore.api.Function;
 import org.apache.hadoop.hive.metastore.api.GetAllFunctionsResponse;
-import org.apache.hadoop.hive.metastore.api.GetChangeVersionRequest;
 import org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprRequest;
 import org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprResult;
 import org.apache.hadoop.hive.metastore.api.GetFileMetadataRequest;
@@ -2419,10 +2418,4 @@ public class HiveMetaStoreClient implements IMetaStoreClient {
     CacheFileMetadataResult result = client.cache_file_metadata(req);
     return result.isIsSupported();
   }
-
-  @Override
-  public long getChangeVersion(String topic) throws TException {
-    return client.get_change_version(new GetChangeVersionRequest(topic)).getVersion();
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/IMetaStoreClient.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/IMetaStoreClient.java b/metastore/src/java/org/apache/hadoop/hive/metastore/IMetaStoreClient.java
index 3965475..de6751f 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/IMetaStoreClient.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/IMetaStoreClient.java
@@ -97,7 +97,6 @@ import java.util.Map.Entry;
 @Public
 @Evolving
 public interface IMetaStoreClient {
-  public static final String PERMANENT_FUNCTION_CV = "PERMANENT_FUNCTION";
 
   /**
    * Returns whether current client is compatible with conf argument or not
@@ -1557,8 +1556,6 @@ public interface IMetaStoreClient {
   boolean cacheFileMetadata(String dbName, String tableName, String partName,
       boolean allParts) throws TException;
 
-  long getChangeVersion(String topic) throws TException;
-
   List<SQLPrimaryKey> getPrimaryKeys(PrimaryKeysRequest request)
     throws MetaException, NoSuchObjectException, TException;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/ObjectStore.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/ObjectStore.java b/metastore/src/java/org/apache/hadoop/hive/metastore/ObjectStore.java
index 550db83..7d64900 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/ObjectStore.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/ObjectStore.java
@@ -112,7 +112,6 @@ import org.apache.hadoop.hive.metastore.api.Type;
 import org.apache.hadoop.hive.metastore.api.UnknownDBException;
 import org.apache.hadoop.hive.metastore.api.UnknownPartitionException;
 import org.apache.hadoop.hive.metastore.api.UnknownTableException;
-import org.apache.hadoop.hive.metastore.model.MChangeVersion;
 import org.apache.hadoop.hive.metastore.model.MColumnDescriptor;
 import org.apache.hadoop.hive.metastore.model.MConstraint;
 import org.apache.hadoop.hive.metastore.model.MDBPrivilege;
@@ -170,7 +169,6 @@ import com.google.common.collect.Lists;
  * to be made into a interface that can read both from a database and a
  * filestore.
  */
-@SuppressWarnings("unchecked")
 public class ObjectStore implements RawStore, Configurable {
   private static Properties prop = null;
   private static PersistenceManagerFactory pmf = null;
@@ -186,11 +184,11 @@ public class ObjectStore implements RawStore, Configurable {
     NO_STATE, OPEN, COMMITED, ROLLBACK
   }
 
-  private static final Map<String, Class<?>> PINCLASSMAP;
+  private static final Map<String, Class> PINCLASSMAP;
   private static final String HOSTNAME;
   private static final String USER;
   static {
-    Map<String, Class<?>> map = new HashMap<String, Class<?>>();
+    Map<String, Class> map = new HashMap<String, Class>();
     map.put("table", MTable.class);
     map.put("storagedescriptor", MStorageDescriptor.class);
     map.put("serdeinfo", MSerDeInfo.class);
@@ -761,9 +759,9 @@ public class ObjectStore implements RawStore, Configurable {
       query = pm.newQuery(queryStr);
       query.setResult("name");
       query.setOrdering("name ascending");
-      Collection<?> names = (Collection<?>) query.execute();
+      Collection names = (Collection) query.execute();
       databases = new ArrayList<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         databases.add((String) i.next());
       }
       commited = commitTransaction();
@@ -1130,9 +1128,9 @@ public class ObjectStore implements RawStore, Configurable {
       query.declareParameters("java.lang.String dbName");
       query.setResult("tableName");
       query.setOrdering("tableName ascending");
-      Collection<?> names = (Collection<?>) query.execute(dbName);
+      Collection names = (Collection) query.execute(dbName);
       tbls = new ArrayList<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         tbls.add((String) i.next());
       }
       commited = commitTransaction();
@@ -1318,8 +1316,8 @@ public class ObjectStore implements RawStore, Configurable {
       query = pm.newQuery(MTable.class);
       query.setFilter("database.name == db && tbl_names.contains(tableName)");
       query.declareParameters("java.lang.String db, java.util.Collection tbl_names");
-      Collection<?> mtables = (Collection<?>) query.execute(db, lowered_tbl_names);
-      for (Iterator<?> iter = mtables.iterator(); iter.hasNext();) {
+      Collection mtables = (Collection) query.execute(db, lowered_tbl_names);
+      for (Iterator iter = mtables.iterator(); iter.hasNext();) {
         tables.add(convertToTable((MTable) iter.next()));
       }
       committed = commitTransaction();
@@ -2186,8 +2184,8 @@ public class ObjectStore implements RawStore, Configurable {
     if (max > 0) {
       query.setRange(0, max);
     }
-    Collection<?> names = (Collection<?>) query.execute(dbName, tableName);
-    for (Iterator<?> i = names.iterator(); i.hasNext();) {
+    Collection names = (Collection) query.execute(dbName, tableName);
+    for (Iterator i = names.iterator(); i.hasNext();) {
       pns.add((String) i.next());
     }
     if (query != null) {
@@ -2211,7 +2209,7 @@ public class ObjectStore implements RawStore, Configurable {
    *          you want results for.  E.g., if resultsCol is partitionName, the Collection
    *          has types of String, and if resultsCol is null, the types are MPartition.
    */
-  private Collection<?> getPartitionPsQueryResults(String dbName, String tableName,
+  private Collection getPartitionPsQueryResults(String dbName, String tableName,
       List<String> part_vals, short max_parts, String resultsCol, QueryWrapper queryWrapper)
       throws MetaException, NoSuchObjectException {
     dbName = HiveStringUtils.normalizeIdentifier(dbName);
@@ -2251,7 +2249,7 @@ public class ObjectStore implements RawStore, Configurable {
       query.setResult(resultsCol);
     }
 
-    return (Collection<?>) query.execute(dbName, tableName, partNameMatcher);
+    return (Collection) query.execute(dbName, tableName, partNameMatcher);
   }
 
   @Override
@@ -2265,7 +2263,7 @@ public class ObjectStore implements RawStore, Configurable {
     try {
       openTransaction();
       LOG.debug("executing listPartitionNamesPsWithAuth");
-      Collection<?> parts = getPartitionPsQueryResults(db_name, tbl_name,
+      Collection parts = getPartitionPsQueryResults(db_name, tbl_name,
           part_vals, max_parts, null, queryWrapper);
       MTable mtbl = getMTable(db_name, tbl_name);
       for (Object o : parts) {
@@ -2301,7 +2299,7 @@ public class ObjectStore implements RawStore, Configurable {
     try {
       openTransaction();
       LOG.debug("Executing listPartitionNamesPs");
-      Collection<?> names = getPartitionPsQueryResults(dbName, tableName,
+      Collection names = getPartitionPsQueryResults(dbName, tableName,
           part_vals, max_parts, "partitionName", queryWrapper);
       for (Object o : names) {
         partitionNames.add((String) o);
@@ -2959,10 +2957,10 @@ public class ObjectStore implements RawStore, Configurable {
       String parameterDeclaration = makeParameterDeclarationStringObj(params);
       query.declareParameters(parameterDeclaration);
       query.setFilter(queryFilterString);
-      Collection<?> names = (Collection<?>)query.executeWithMap(params);
+      Collection names = (Collection)query.executeWithMap(params);
       // have to emulate "distinct", otherwise tables with the same name may be returned
       Set<String> tableNamesSet = new HashSet<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         tableNamesSet.add((String) i.next());
       }
       tableNames = new ArrayList<String>(tableNamesSet);
@@ -3012,9 +3010,9 @@ public class ObjectStore implements RawStore, Configurable {
       query.declareParameters(parameterDeclaration);
       query.setOrdering("partitionName ascending");
       query.setResult("partitionName");
-      Collection<?> names = (Collection<?>) query.executeWithMap(params);
+      Collection names = (Collection) query.executeWithMap(params);
       partNames = new ArrayList<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         partNames.add((String) i.next());
       }
       LOG.debug("Done executing query for listMPartitionNamesByFilter");
@@ -3646,8 +3644,8 @@ public class ObjectStore implements RawStore, Configurable {
               + "order by indexName asc");
       query.declareParameters("java.lang.String t1, java.lang.String t2");
       query.setResult("indexName");
-      Collection<?> names = (Collection<?>) query.execute(dbName, origTableName);
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      Collection names = (Collection) query.execute(dbName, origTableName);
+      for (Iterator i = names.iterator(); i.hasNext();) {
         pns.add((String) i.next());
       }
       success = commitTransaction();
@@ -4052,9 +4050,9 @@ public class ObjectStore implements RawStore, Configurable {
       LOG.debug("Executing listAllRoleNames");
       query = pm.newQuery("select roleName from org.apache.hadoop.hive.metastore.model.MRole");
       query.setResult("roleName");
-      Collection<?> names = (Collection<?>) query.execute();
+      Collection names = (Collection) query.execute();
       List<String> roleNames = new ArrayList<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         roleNames.add((String) i.next());
       }
       success = commitTransaction();
@@ -7767,7 +7765,6 @@ public class ObjectStore implements RawStore, Configurable {
       openTransaction();
       MFunction mfunc = convertToMFunction(func);
       pm.makePersistent(mfunc);
-      incrementChangeVersionNoTx(IMetaStoreClient.PERMANENT_FUNCTION_CV);
       committed = commitTransaction();
     } finally {
       if (!committed) {
@@ -7794,8 +7791,6 @@ public class ObjectStore implements RawStore, Configurable {
         throw new MetaException("function " + funcName + " doesn't exist");
       }
 
-      incrementChangeVersionNoTx(IMetaStoreClient.PERMANENT_FUNCTION_CV);
-
       // For now only alter name, owner, class name, type
       oldf.setFunctionName(HiveStringUtils.normalizeIdentifier(newf.getFunctionName()));
       oldf.setDatabase(newf.getDatabase());
@@ -7813,15 +7808,6 @@ public class ObjectStore implements RawStore, Configurable {
     }
   }
 
-  private void incrementChangeVersionNoTx(String topic) {
-    MChangeVersion cv = getMChangeVersionNoTx(topic);
-    if (cv == null) {
-      cv = new MChangeVersion(topic, 1);
-      pm.makePersistent(cv);
-    }
-    cv.setVersion(cv.getVersion() + 1);
-  }
-
   @Override
   public void dropFunction(String dbName, String funcName) throws MetaException,
   NoSuchObjectException, InvalidObjectException, InvalidInputException {
@@ -7834,7 +7820,6 @@ public class ObjectStore implements RawStore, Configurable {
         // TODO: When function privileges are implemented, they should be deleted here.
         pm.deletePersistentAll(mfunc);
       }
-      incrementChangeVersionNoTx(IMetaStoreClient.PERMANENT_FUNCTION_CV);
       success = commitTransaction();
     } finally {
       if (!success) {
@@ -7868,27 +7853,6 @@ public class ObjectStore implements RawStore, Configurable {
     return mfunc;
   }
 
-  private MChangeVersion getMChangeVersionNoTx(String topic) {
-    Query query = null;
-    try {
-      query = pm.newQuery(MChangeVersion.class, "topic == topicName");
-      query.declareParameters("java.lang.String topicName");
-      query.setUnique(true);
-      Object obj = query.execute(topic);
-      if (obj == null) {
-        return null;
-      } else {
-        MChangeVersion mversion = (MChangeVersion)obj;
-        pm.retrieve(mversion);
-        return mversion;
-      }
-    } finally {
-      if (query != null) {
-        query.closeAll();
-      }
-    }
-  }
-
   @Override
   public Function getFunction(String dbName, String funcName) throws MetaException {
     boolean commited = false;
@@ -7906,21 +7870,6 @@ public class ObjectStore implements RawStore, Configurable {
   }
 
   @Override
-  public long getChangeVersion(String topic) throws MetaException {
-    boolean commited = false;
-    try {
-      openTransaction();
-      long result = getMChangeVersionNoTx(topic).getVersion();
-      commited = commitTransaction();
-      return result;
-    } finally {
-      if (!commited) {
-        rollbackTransaction();
-      }
-    }
-  }
-
-  @Override
   public List<Function> getAllFunctions() throws MetaException {
     boolean commited = false;
     try {
@@ -7965,9 +7914,9 @@ public class ObjectStore implements RawStore, Configurable {
       query.declareParameters("java.lang.String dbName");
       query.setResult("functionName");
       query.setOrdering("functionName ascending");
-      Collection<?> names = (Collection<?>) query.execute(dbName);
+      Collection names = (Collection) query.execute(dbName);
       funcs = new ArrayList<String>();
-      for (Iterator<?> i = names.iterator(); i.hasNext();) {
+      for (Iterator i = names.iterator(); i.hasNext();) {
         funcs.add((String) i.next());
       }
       commited = commitTransaction();
@@ -7992,8 +7941,7 @@ public class ObjectStore implements RawStore, Configurable {
       query = pm.newQuery(MNotificationLog.class, "eventId > lastEvent");
       query.declareParameters("java.lang.Long lastEvent");
       query.setOrdering("eventId ascending");
-      Collection<MNotificationLog> events = (Collection<MNotificationLog>)
-          query.execute(lastEvent);
+      Collection<MNotificationLog> events = (Collection) query.execute(lastEvent);
       commited = commitTransaction();
       if (events == null) {
         return null;

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/RawStore.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/RawStore.java b/metastore/src/java/org/apache/hadoop/hive/metastore/RawStore.java
index 06b8135..07d8119 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/RawStore.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/RawStore.java
@@ -663,9 +663,6 @@ public interface RawStore extends Configurable {
   @InterfaceStability.Evolving
   int getDatabaseCount() throws MetaException;
 
-  @InterfaceStability.Evolving
-  long getChangeVersion(String topic) throws MetaException;
-
   public abstract List<SQLPrimaryKey> getPrimaryKeys(String db_name,
     String tbl_name) throws MetaException;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseReadWrite.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseReadWrite.java b/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseReadWrite.java
index 2860875..e0275f9 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseReadWrite.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseReadWrite.java
@@ -132,7 +132,6 @@ public class HBaseReadWrite implements MetadataStore {
   // The change version functionality uses the sequences table, but we don't want to give the
   // caller complete control over the sequence name as they might inadvertently clash with one of
   // our sequence keys, so add a prefix to their topic name.
-  final static String CHANGE_VERSION_SEQUENCE_PREFIX = "cv_";
 
   final static byte[] AGGR_STATS_BLOOM_COL = "b".getBytes(HBaseUtils.ENCODING);
   private final static byte[] AGGR_STATS_STATS_COL = "s".getBytes(HBaseUtils.ENCODING);
@@ -142,6 +141,7 @@ public class HBaseReadWrite implements MetadataStore {
   private final static byte[] DELEGATION_TOKEN_COL = "dt".getBytes(HBaseUtils.ENCODING);
   private final static byte[] MASTER_KEY_COL = "mk".getBytes(HBaseUtils.ENCODING);
   private final static byte[] GLOBAL_PRIVS_KEY = "gp".getBytes(HBaseUtils.ENCODING);
+  private final static byte[] SEQUENCES_KEY = "seq".getBytes(HBaseUtils.ENCODING);
   private final static int TABLES_TO_CACHE = 10;
   // False positives are very bad here because they cause us to invalidate entries we shouldn't.
   // Space used and # of hash functions grows in proportion to ln of num bits so a 10x increase
@@ -2142,23 +2142,6 @@ public class HBaseReadWrite implements MetadataStore {
   }
 
   /**********************************************************************************************
-   * Change version related methods
-   *********************************************************************************************/
-
-  public long getChangeVersion(String topic) throws IOException {
-    byte[] key = HBaseUtils.buildKey(CHANGE_VERSION_SEQUENCE_PREFIX + topic);
-    return peekAtSequence(key);
-  }
-
-  // TODO: The way this is called now is not ideal. It's all encapsulated and stuff, but,
-  //       before the txns (consistent HBase writes) are properly implemented, we should at least
-  //       put this in the same RPC with real updates. But there are no guarantees anyway, so...
-  public void incrementChangeVersion(String topic) throws IOException {
-    byte[] key = HBaseUtils.buildKey(CHANGE_VERSION_SEQUENCE_PREFIX + topic);
-    getNextSequence(key);
-  }
-
-  /**********************************************************************************************
    * File metadata related methods
    *********************************************************************************************/
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseStore.java
----------------------------------------------------------------------
diff --git a/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseStore.java b/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseStore.java
index ec5b92c..e97d4a9 100644
--- a/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseStore.java
+++ b/metastore/src/java/org/apache/hadoop/hive/metastore/hbase/HBaseStore.java
@@ -30,7 +30,6 @@ import org.apache.hadoop.hive.common.StatsSetupConst;
 import org.apache.hadoop.hive.conf.HiveConf;
 import org.apache.hadoop.hive.metastore.FileMetadataHandler;
 import org.apache.hadoop.hive.metastore.HiveMetaStore;
-import org.apache.hadoop.hive.metastore.IMetaStoreClient;
 import org.apache.hadoop.hive.metastore.PartFilterExprUtil;
 import org.apache.hadoop.hive.metastore.PartitionExpressionProxy;
 import org.apache.hadoop.hive.metastore.RawStore;
@@ -2252,9 +2251,7 @@ public class HBaseStore implements RawStore {
     boolean commit = false;
     openTransaction();
     try {
-      HBaseReadWrite hbase = getHBase();
-      hbase.putFunction(func);
-      hbase.incrementChangeVersion(IMetaStoreClient.PERMANENT_FUNCTION_CV);
+      getHBase().putFunction(func);
       commit = true;
     } catch (IOException e) {
       LOG.error("Unable to create function", e);
@@ -2270,9 +2267,7 @@ public class HBaseStore implements RawStore {
     boolean commit = false;
     openTransaction();
     try {
-      HBaseReadWrite hbase = getHBase();
-      hbase.putFunction(newFunction);
-      hbase.incrementChangeVersion(IMetaStoreClient.PERMANENT_FUNCTION_CV);
+      getHBase().putFunction(newFunction);
       commit = true;
     } catch (IOException e) {
       LOG.error("Unable to alter function ", e);
@@ -2288,9 +2283,7 @@ public class HBaseStore implements RawStore {
     boolean commit = false;
     openTransaction();
     try {
-      HBaseReadWrite hbase = getHBase();
-      hbase.deleteFunction(dbName, funcName);
-      hbase.incrementChangeVersion(IMetaStoreClient.PERMANENT_FUNCTION_CV);
+      getHBase().deleteFunction(dbName, funcName);
       commit = true;
     } catch (IOException e) {
       LOG.error("Unable to delete function" + e);
@@ -2580,21 +2573,6 @@ public class HBaseStore implements RawStore {
   }
 
   @Override
-  public long getChangeVersion(String topic) throws MetaException {
-    openTransaction();
-    boolean commit = true;
-    try {
-      return getHBase().getChangeVersion(topic);
-    } catch (IOException e) {
-      commit = false;
-      LOG.error("Unable to get change version", e);
-      throw new MetaException("Unable to get change version " + e.getMessage());
-    } finally {
-      commitOrRoleBack(commit);
-    }
-  }
-
-  @Override
   public List<SQLPrimaryKey> getPrimaryKeys(String db_name, String tbl_name)
     throws MetaException {
     // TODO Auto-generated method stub

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/model/org/apache/hadoop/hive/metastore/model/MChangeVersion.java
----------------------------------------------------------------------
diff --git a/metastore/src/model/org/apache/hadoop/hive/metastore/model/MChangeVersion.java b/metastore/src/model/org/apache/hadoop/hive/metastore/model/MChangeVersion.java
deleted file mode 100644
index d498c86..0000000
--- a/metastore/src/model/org/apache/hadoop/hive/metastore/model/MChangeVersion.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you 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 org.apache.hadoop.hive.metastore.model;
-
-public class MChangeVersion {
-  private String topic;
-  private long version;
-
-  public MChangeVersion() {
-  }
-
-  public MChangeVersion(String topic, long version) {
-    this.setTopic(topic);
-    this.setVersion(version);
-  }
-
-  public String getTopic() {
-    return topic;
-  }
-
-  public void setTopic(String topic) {
-    this.topic = topic;
-  }
-
-  public long getVersion() {
-    return version;
-  }
-
-  public void setVersion(long version) {
-    this.version = version;
-  }
-}

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/model/package.jdo
----------------------------------------------------------------------
diff --git a/metastore/src/model/package.jdo b/metastore/src/model/package.jdo
index b40df39..a58c046 100644
--- a/metastore/src/model/package.jdo
+++ b/metastore/src/model/package.jdo
@@ -1052,18 +1052,7 @@
       </field>
     </class>
 
-    <class name="MChangeVersion" table="CHANGE_VERSION" identity-type="datastore" detachable="true">
-      <datastore-identity>
-        <column name="CHANGE_VERSION_ID"/>
-      </datastore-identity>
-      <field name="version">
-        <column name="VERSION" jdbc-type="BIGINT" allows-null="false"/>
-      </field>
-      <field name="topic">
-        <column name="TOPIC" length="255" jdbc-type="VARCHAR" allows-null="false"/>
-        <index name="UniqueTopic" unique="true"/>
-      </field>
-    </class>
+
   </package>
 </jdo>
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreControlledCommit.java
----------------------------------------------------------------------
diff --git a/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreControlledCommit.java b/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreControlledCommit.java
index 63fcb28..7f4b77e 100644
--- a/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreControlledCommit.java
+++ b/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreControlledCommit.java
@@ -819,11 +819,6 @@ public class DummyRawStoreControlledCommit implements RawStore, Configurable {
   }
 
   @Override
-  public long getChangeVersion(String topic) throws MetaException {
-    return 0;
-  }
-
-  @Override
   public List<SQLPrimaryKey> getPrimaryKeys(String db_name, String tbl_name)
     throws MetaException {
     // TODO Auto-generated method stub

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreForJdoConnection.java
----------------------------------------------------------------------
diff --git a/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreForJdoConnection.java b/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreForJdoConnection.java
index 386c70a..25ccced 100644
--- a/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreForJdoConnection.java
+++ b/metastore/src/test/org/apache/hadoop/hive/metastore/DummyRawStoreForJdoConnection.java
@@ -835,11 +835,6 @@ public class DummyRawStoreForJdoConnection implements RawStore {
   }
 
   @Override
-  public long getChangeVersion(String topic) throws MetaException {
-    return 0;
-  }
-
-  @Override
   public List<SQLPrimaryKey> getPrimaryKeys(String db_name, String tbl_name)
     throws MetaException {
     // TODO Auto-generated method stub

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java b/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java
index 2ca4d1e..6cacc59 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java
@@ -3602,14 +3602,6 @@ private void constructOneLBLocationMap(FileStatus fSta,
     }
   }
 
-  public long getPermanenFunctionsChangeVersion() throws HiveException {
-    try {
-      return getMSC().getChangeVersion(IMetaStoreClient.PERMANENT_FUNCTION_CV);
-    } catch (TException e) {
-      throw new HiveException(e);
-    }
-  }
-
   public void dropConstraint(String dbName, String tableName, String constraintName)
     throws HiveException, NoSuchObjectException {
     try {


[5/5] hive git commit: HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)

Posted by se...@apache.org.
HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)


Project: http://git-wip-us.apache.org/repos/asf/hive/repo
Commit: http://git-wip-us.apache.org/repos/asf/hive/commit/10c07d6e
Tree: http://git-wip-us.apache.org/repos/asf/hive/tree/10c07d6e
Diff: http://git-wip-us.apache.org/repos/asf/hive/diff/10c07d6e

Branch: refs/heads/master
Commit: 10c07d6ec265f747c1a27597c6ad3683054e760d
Parents: c204dd7
Author: Sergey Shelukhin <se...@apache.org>
Authored: Mon May 9 12:39:04 2016 -0700
Committer: Sergey Shelukhin <se...@apache.org>
Committed: Mon May 9 12:39:04 2016 -0700

----------------------------------------------------------------------
 metastore/if/hive_metastore.thrift              |   13 +-
 .../upgrade/derby/033-HIVE-12892.derby.sql      |    3 -
 .../upgrade/derby/hive-schema-2.1.0.derby.sql   |    7 -
 .../derby/upgrade-2.0.0-to-2.1.0.derby.sql      |    1 -
 .../upgrade/mssql/018-HIVE-12892.mssql.sql      |    9 -
 .../upgrade/mssql/hive-schema-2.1.0.mssql.sql   |   13 -
 .../mssql/upgrade-2.0.0-to-2.1.0.mssql.sql      |    1 -
 .../upgrade/mysql/033-HIVE-12892.mysql.sql      |   10 -
 .../upgrade/mysql/hive-schema-2.1.0.mysql.sql   |   11 -
 .../mysql/upgrade-2.0.0-to-2.1.0.mysql.sql      |    1 -
 .../upgrade/oracle/033-HIVE-12892.oracle.sql    |    7 -
 .../upgrade/oracle/hive-schema-2.1.0.oracle.sql |   11 +-
 .../oracle/upgrade-2.0.0-to-2.1.0.oracle.sql    |    1 -
 .../postgres/032-HIVE-12892.postgres.sql        |   10 -
 .../postgres/hive-schema-2.1.0.postgres.sql     |   14 -
 .../upgrade-2.0.0-to-2.1.0.postgres.sql         |    1 -
 .../gen/thrift/gen-cpp/ThriftHiveMetastore.cpp  | 2403 ++++++++----------
 .../gen/thrift/gen-cpp/ThriftHiveMetastore.h    |  126 -
 .../ThriftHiveMetastore_server.skeleton.cpp     |    5 -
 .../gen/thrift/gen-cpp/hive_metastore_types.cpp |  736 ++----
 .../gen/thrift/gen-cpp/hive_metastore_types.h   |   84 -
 .../metastore/api/GetChangeVersionRequest.java  |  389 ---
 .../metastore/api/GetChangeVersionResult.java   |  387 ---
 .../hive/metastore/api/ThriftHiveMetastore.java | 1622 +++---------
 .../gen-php/metastore/ThriftHiveMetastore.php   |  216 --
 .../src/gen/thrift/gen-php/metastore/Types.php  |  150 --
 .../hive_metastore/ThriftHiveMetastore-remote   |    7 -
 .../hive_metastore/ThriftHiveMetastore.py       |  189 --
 .../gen/thrift/gen-py/hive_metastore/ttypes.py  |  134 -
 .../gen/thrift/gen-rb/hive_metastore_types.rb   |   34 -
 .../gen/thrift/gen-rb/thrift_hive_metastore.rb  |   54 -
 .../hadoop/hive/metastore/HiveMetaStore.java    |    8 -
 .../hive/metastore/HiveMetaStoreClient.java     |    7 -
 .../hadoop/hive/metastore/IMetaStoreClient.java |    3 -
 .../hadoop/hive/metastore/ObjectStore.java      |  102 +-
 .../apache/hadoop/hive/metastore/RawStore.java  |    3 -
 .../hive/metastore/hbase/HBaseReadWrite.java    |   19 +-
 .../hadoop/hive/metastore/hbase/HBaseStore.java |   28 +-
 .../hive/metastore/model/MChangeVersion.java    |   48 -
 metastore/src/model/package.jdo                 |   13 +-
 .../DummyRawStoreControlledCommit.java          |    5 -
 .../DummyRawStoreForJdoConnection.java          |    5 -
 .../apache/hadoop/hive/ql/metadata/Hive.java    |    8 -
 43 files changed, 1706 insertions(+), 5192 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/if/hive_metastore.thrift
----------------------------------------------------------------------
diff --git a/metastore/if/hive_metastore.thrift b/metastore/if/hive_metastore.thrift
index c8d78b6..7558046 100755
--- a/metastore/if/hive_metastore.thrift
+++ b/metastore/if/hive_metastore.thrift
@@ -794,17 +794,7 @@ struct FireEventRequest {
 struct FireEventResponse {
     // NOP for now, this is just a place holder for future responses
 }
-
-
-struct GetChangeVersionRequest {
-  1: required string topic
-}
-
-struct GetChangeVersionResult {
-  1: required i64 version
-}
-
-
+    
 struct MetadataPpdResult {
   1: optional binary metadata,
   2: optional binary includeBitset
@@ -1416,7 +1406,6 @@ service ThriftHiveMetastore extends fb303.FacebookService
   ClearFileMetadataResult clear_file_metadata(1:ClearFileMetadataRequest req)
   CacheFileMetadataResult cache_file_metadata(1:CacheFileMetadataRequest req)
 
-  GetChangeVersionResult get_change_version(1:GetChangeVersionRequest req)
 }
 
 // * Note about the DDL_TIME: When creating or altering a table or a partition,

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/derby/033-HIVE-12892.derby.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/derby/033-HIVE-12892.derby.sql b/metastore/scripts/upgrade/derby/033-HIVE-12892.derby.sql
deleted file mode 100644
index ab004d9..0000000
--- a/metastore/scripts/upgrade/derby/033-HIVE-12892.derby.sql
+++ /dev/null
@@ -1,3 +0,0 @@
-CREATE TABLE "APP"."CHANGE_VERSION" ("CHANGE_VERSION_ID" BIGINT NOT NULL, "VERSION" BIGINT NOT NULL, "TOPIC" VARCHAR(255));
-ALTER TABLE "APP"."CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_PK" PRIMARY KEY ("CHANGE_VERSION_ID");
-CREATE UNIQUE INDEX "APP"."UNIQUECHANGEVERSION" ON "APP"."CHANGE_VERSION" ("TOPIC");

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/derby/hive-schema-2.1.0.derby.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/derby/hive-schema-2.1.0.derby.sql b/metastore/scripts/upgrade/derby/hive-schema-2.1.0.derby.sql
index dc27afc..e5d3e89 100644
--- a/metastore/scripts/upgrade/derby/hive-schema-2.1.0.derby.sql
+++ b/metastore/scripts/upgrade/derby/hive-schema-2.1.0.derby.sql
@@ -98,8 +98,6 @@ CREATE TABLE "APP"."PART_COL_STATS"("DB_NAME" VARCHAR(128) NOT NULL,"TABLE_NAME"
 
 CREATE TABLE "APP"."VERSION" ("VER_ID" BIGINT NOT NULL, "SCHEMA_VERSION" VARCHAR(127) NOT NULL, "VERSION_COMMENT" VARCHAR(255));
 
-CREATE TABLE "APP"."CHANGE_VERSION" ("CHANGE_VERSION_ID" BIGINT NOT NULL, "VERSION" BIGINT NOT NULL, "TOPIC" VARCHAR(255));
-
 CREATE TABLE "APP"."FUNCS" ("FUNC_ID" BIGINT NOT NULL, "CLASS_NAME" VARCHAR(4000), "CREATE_TIME" INTEGER NOT NULL, "DB_ID" BIGINT, "FUNC_NAME" VARCHAR(128), "FUNC_TYPE" INTEGER NOT NULL, "OWNER_NAME" VARCHAR(128), "OWNER_TYPE" VARCHAR(10));
 
 CREATE TABLE "APP"."FUNC_RU" ("FUNC_ID" BIGINT NOT NULL, "RESOURCE_TYPE" INTEGER NOT NULL, "RESOURCE_URI" VARCHAR(4000), "INTEGER_IDX" INTEGER NOT NULL);
@@ -318,11 +316,6 @@ ALTER TABLE "APP"."PART_COL_STATS" ADD CONSTRAINT "PART_COL_STATS_FK" FOREIGN KE
 
 ALTER TABLE "APP"."VERSION" ADD CONSTRAINT "VERSION_PK" PRIMARY KEY ("VER_ID");
 
-ALTER TABLE "APP"."CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_PK" PRIMARY KEY ("CHANGE_VERSION_ID");
-
-CREATE UNIQUE INDEX "APP"."UNIQUECHANGEVERSION" ON "APP"."CHANGE_VERSION" ("TOPIC");
-
-
 ALTER TABLE "APP"."FUNCS" ADD CONSTRAINT "FUNCS_FK1" FOREIGN KEY ("DB_ID") REFERENCES "APP"."DBS" ("DB_ID") ON DELETE NO ACTION ON UPDATE NO ACTION;
 
 ALTER TABLE "APP"."FUNC_RU" ADD CONSTRAINT "FUNC_RU_FK1" FOREIGN KEY ("FUNC_ID") REFERENCES "APP"."FUNCS" ("FUNC_ID") ON DELETE NO ACTION ON UPDATE NO ACTION;

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/derby/upgrade-2.0.0-to-2.1.0.derby.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/derby/upgrade-2.0.0-to-2.1.0.derby.sql b/metastore/scripts/upgrade/derby/upgrade-2.0.0-to-2.1.0.derby.sql
index 94c686b..9c730af 100644
--- a/metastore/scripts/upgrade/derby/upgrade-2.0.0-to-2.1.0.derby.sql
+++ b/metastore/scripts/upgrade/derby/upgrade-2.0.0-to-2.1.0.derby.sql
@@ -1,5 +1,4 @@
 -- Upgrade MetaStore schema from 2.0.0 to 2.1.0
-RUN '033-HIVE-12892.derby.sql';
 RUN '034-HIVE-13076.derby.sql';
 RUN '035-HIVE-13395.derby.sql';
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mssql/018-HIVE-12892.mssql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mssql/018-HIVE-12892.mssql.sql b/metastore/scripts/upgrade/mssql/018-HIVE-12892.mssql.sql
deleted file mode 100644
index a13591d..0000000
--- a/metastore/scripts/upgrade/mssql/018-HIVE-12892.mssql.sql
+++ /dev/null
@@ -1,9 +0,0 @@
--- Table CHANGE_VERSION
-CREATE TABLE CHANGE_VERSION
-(
-    CHANGE_VERSION_ID bigint NOT NULL,
-    VERSION bigint NOT NULL,
-    TOPIC nvarchar(255) NOT NULL
-);
-ALTER TABLE CHANGE_VERSION ADD CONSTRAINT CHANGE_VERSION_PK PRIMARY KEY (CHANGE_VERSION_ID);
-CREATE UNIQUE INDEX UNIQUECHANGEVERSION ON CHANGE_VERSION (TOPIC);

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mssql/hive-schema-2.1.0.mssql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mssql/hive-schema-2.1.0.mssql.sql b/metastore/scripts/upgrade/mssql/hive-schema-2.1.0.mssql.sql
index d9194ff..4f0fdd6 100644
--- a/metastore/scripts/upgrade/mssql/hive-schema-2.1.0.mssql.sql
+++ b/metastore/scripts/upgrade/mssql/hive-schema-2.1.0.mssql.sql
@@ -165,19 +165,6 @@ CREATE TABLE VERSION
 
 ALTER TABLE VERSION ADD CONSTRAINT VERSION_PK PRIMARY KEY (VER_ID);
 
--- Table CHANGE_VERSION
-CREATE TABLE CHANGE_VERSION
-(
-    CHANGE_VERSION_ID bigint NOT NULL,
-    VERSION bigint NOT NULL,
-    TOPIC nvarchar(255) NOT NULL
-);
-
-ALTER TABLE CHANGE_VERSION ADD CONSTRAINT CHANGE_VERSION_PK PRIMARY KEY (CHANGE_VERSION_ID);
-
-CREATE UNIQUE INDEX UNIQUECHANGEVERSION ON CHANGE_VERSION (TOPIC);
-
-
 -- Table GLOBAL_PRIVS for classes [org.apache.hadoop.hive.metastore.model.MGlobalPrivilege]
 CREATE TABLE GLOBAL_PRIVS
 (

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mssql/upgrade-2.0.0-to-2.1.0.mssql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mssql/upgrade-2.0.0-to-2.1.0.mssql.sql b/metastore/scripts/upgrade/mssql/upgrade-2.0.0-to-2.1.0.mssql.sql
index c796126..f42f2c3 100644
--- a/metastore/scripts/upgrade/mssql/upgrade-2.0.0-to-2.1.0.mssql.sql
+++ b/metastore/scripts/upgrade/mssql/upgrade-2.0.0-to-2.1.0.mssql.sql
@@ -1,6 +1,5 @@
 SELECT 'Upgrading MetaStore schema from 2.0.0 to 2.1.0' AS MESSAGE;
 
-:r 018-HIVE-12892.mssql.sql;
 :r 019-HIVE-13076.mssql.sql;
 :r 020-HIVE-13395.mssql.sql;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mysql/033-HIVE-12892.mysql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mysql/033-HIVE-12892.mysql.sql b/metastore/scripts/upgrade/mysql/033-HIVE-12892.mysql.sql
deleted file mode 100644
index 783afe8..0000000
--- a/metastore/scripts/upgrade/mysql/033-HIVE-12892.mysql.sql
+++ /dev/null
@@ -1,10 +0,0 @@
--- Table structure for CHANGE_VERSION
---
-CREATE TABLE IF NOT EXISTS `CHANGE_VERSION` (
-  `CHANGE_VERSION_ID` BIGINT NOT NULL,
-  `VERSION` BIGINT NOT NULL,
-  `TOPIC` VARCHAR(255) NOT NULL,
-  PRIMARY KEY (`CHANGE_VERSION_ID`),
-  UNIQUE KEY `UNIQUECHANGEVERSION` (`TOPIC`)
-) ENGINE=InnoDB DEFAULT CHARSET=latin1;
---

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mysql/hive-schema-2.1.0.mysql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mysql/hive-schema-2.1.0.mysql.sql b/metastore/scripts/upgrade/mysql/hive-schema-2.1.0.mysql.sql
index a6b783c..5c03b65 100644
--- a/metastore/scripts/upgrade/mysql/hive-schema-2.1.0.mysql.sql
+++ b/metastore/scripts/upgrade/mysql/hive-schema-2.1.0.mysql.sql
@@ -760,17 +760,6 @@ CREATE TABLE IF NOT EXISTS `VERSION` (
 ) ENGINE=InnoDB DEFAULT CHARSET=latin1;
 
 --
--- Table structure for CHANGE_VERSION
---
-CREATE TABLE IF NOT EXISTS `CHANGE_VERSION` (
-  `CHANGE_VERSION_ID` BIGINT NOT NULL,
-  `VERSION` BIGINT NOT NULL,
-  `TOPIC` VARCHAR(255) NOT NULL,
-  PRIMARY KEY (`CHANGE_VERSION_ID`),
-  UNIQUE KEY `UNIQUECHANGEVERSION` (`TOPIC`)
-) ENGINE=InnoDB DEFAULT CHARSET=latin1;
-
---
 -- Table structure for table FUNCS
 --
 CREATE TABLE IF NOT EXISTS `FUNCS` (

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/mysql/upgrade-2.0.0-to-2.1.0.mysql.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/mysql/upgrade-2.0.0-to-2.1.0.mysql.sql b/metastore/scripts/upgrade/mysql/upgrade-2.0.0-to-2.1.0.mysql.sql
index c3f83b3..ddc17d8 100644
--- a/metastore/scripts/upgrade/mysql/upgrade-2.0.0-to-2.1.0.mysql.sql
+++ b/metastore/scripts/upgrade/mysql/upgrade-2.0.0-to-2.1.0.mysql.sql
@@ -1,6 +1,5 @@
 SELECT 'Upgrading MetaStore schema from 2.0.0 to 2.1.0' AS ' ';
 
-SOURCE 033-HIVE-12892.mysql.sql;
 SOURCE 034-HIVE-13076.mysql.sql;
 SOURCE 035-HIVE-12295.mysql.sql;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/oracle/033-HIVE-12892.oracle.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/oracle/033-HIVE-12892.oracle.sql b/metastore/scripts/upgrade/oracle/033-HIVE-12892.oracle.sql
deleted file mode 100644
index d2bd9d5..0000000
--- a/metastore/scripts/upgrade/oracle/033-HIVE-12892.oracle.sql
+++ /dev/null
@@ -1,7 +0,0 @@
-CREATE TABLE CHANGE_VERSION (
-  CHANGE_VERSION_ID NUMBER NOT NULL,
-  VERSION NUMBER NOT NULL,
-  TOPIC VARCHAR(255) NOT NULL
-);
-ALTER TABLE CHANGE_VERSION ADD CONSTRAINT CHANGE_VERSION_PK PRIMARY KEY (CHANGE_VERSION_ID);
-CREATE UNIQUE INDEX UNIQUE_CHANGE_VERSION ON CHANGE_VERSION (TOPIC);

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/oracle/hive-schema-2.1.0.oracle.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/oracle/hive-schema-2.1.0.oracle.sql b/metastore/scripts/upgrade/oracle/hive-schema-2.1.0.oracle.sql
index d003a16..8420661 100644
--- a/metastore/scripts/upgrade/oracle/hive-schema-2.1.0.oracle.sql
+++ b/metastore/scripts/upgrade/oracle/hive-schema-2.1.0.oracle.sql
@@ -488,19 +488,10 @@ CREATE TABLE TAB_COL_STATS (
 CREATE TABLE VERSION (
   VER_ID NUMBER NOT NULL,
   SCHEMA_VERSION VARCHAR(127) NOT NULL,
-  VERSION_COMMENT VARCHAR(255) NOT NULL
+  VERSION_COMMENT VARCHAR(255)
 );
 ALTER TABLE VERSION ADD CONSTRAINT VERSION_PK PRIMARY KEY (VER_ID);
 
-CREATE TABLE CHANGE_VERSION (
-  CHANGE_VERSION_ID NUMBER NOT NULL,
-  VERSION NUMBER NOT NULL,
-  TOPIC VARCHAR(255) NOT NULL
-);
-ALTER TABLE CHANGE_VERSION ADD CONSTRAINT CHANGE_VERSION_PK PRIMARY KEY (CHANGE_VERSION_ID);
-
-CREATE UNIQUE INDEX UNIQUE_CHANGE_VERSION ON CHANGE_VERSION (TOPIC);
-
 ALTER TABLE TAB_COL_STATS ADD CONSTRAINT TAB_COL_STATS_PKEY PRIMARY KEY (CS_ID);
 
 ALTER TABLE TAB_COL_STATS ADD CONSTRAINT TAB_COL_STATS_FK FOREIGN KEY (TBL_ID) REFERENCES TBLS (TBL_ID) INITIALLY DEFERRED ;

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/oracle/upgrade-2.0.0-to-2.1.0.oracle.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/oracle/upgrade-2.0.0-to-2.1.0.oracle.sql b/metastore/scripts/upgrade/oracle/upgrade-2.0.0-to-2.1.0.oracle.sql
index a226d9a..e27047e 100644
--- a/metastore/scripts/upgrade/oracle/upgrade-2.0.0-to-2.1.0.oracle.sql
+++ b/metastore/scripts/upgrade/oracle/upgrade-2.0.0-to-2.1.0.oracle.sql
@@ -1,6 +1,5 @@
 SELECT 'Upgrading MetaStore schema from 2.0.0 to 2.1.0' AS Status from dual;
 
-@033-HIVE-12892.oracle.sql;
 @034-HIVE-13076.oracle.sql;
 @035-HIVE-13395.oracle.sql;
 

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/postgres/032-HIVE-12892.postgres.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/postgres/032-HIVE-12892.postgres.sql b/metastore/scripts/upgrade/postgres/032-HIVE-12892.postgres.sql
deleted file mode 100644
index 302c51a..0000000
--- a/metastore/scripts/upgrade/postgres/032-HIVE-12892.postgres.sql
+++ /dev/null
@@ -1,10 +0,0 @@
--- Table structure for CHANGE_VERSION
---
-CREATE TABLE "CHANGE_VERSION" (
-  "CHANGE_VERSION_ID" bigint,
-  "VERSION" bigint NOT NULL,
-  "TOPIC" character varying(255) NOT NULL
-);
---
-ALTER TABLE ONLY "CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_pkey" PRIMARY KEY ("CHANGE_VERSION_ID");
-ALTER TABLE ONLY "CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_UNIQUE" UNIQUE ("TOPIC");

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/postgres/hive-schema-2.1.0.postgres.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/postgres/hive-schema-2.1.0.postgres.sql b/metastore/scripts/upgrade/postgres/hive-schema-2.1.0.postgres.sql
index 43e984c..f9bf2a3 100644
--- a/metastore/scripts/upgrade/postgres/hive-schema-2.1.0.postgres.sql
+++ b/metastore/scripts/upgrade/postgres/hive-schema-2.1.0.postgres.sql
@@ -514,15 +514,6 @@ CREATE TABLE "VERSION" (
 );
 
 --
--- Table structure for CHANGE_VERSION
---
-CREATE TABLE "CHANGE_VERSION" (
-  "CHANGE_VERSION_ID" bigint,
-  "VERSION" bigint NOT NULL,
-  "TOPIC" character varying(255) NOT NULL
-);
-
---
 -- Name: PART_COL_STATS Type: TABLE; Schema: public; Owner: hiveuser; Tablespace:
 --
 
@@ -1453,11 +1444,6 @@ ALTER TABLE ONLY "PART_COL_STATS" ADD CONSTRAINT "PART_COL_STATS_fkey" FOREIGN K
 
 ALTER TABLE ONLY "VERSION" ADD CONSTRAINT "VERSION_pkey" PRIMARY KEY ("VER_ID");
 
-ALTER TABLE ONLY "CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_pkey" PRIMARY KEY ("CHANGE_VERSION_ID");
-
-ALTER TABLE ONLY "CHANGE_VERSION" ADD CONSTRAINT "CHANGE_VERSION_UNIQUE" UNIQUE ("TOPIC");
-
-
 -- Name: FUNCS_FK1; Type: FK CONSTRAINT; Schema: public; Owner: hiveuser
 ALTER TABLE ONLY "FUNCS"
     ADD CONSTRAINT "FUNCS_FK1" FOREIGN KEY ("DB_ID") REFERENCES "DBS" ("DB_ID") DEFERRABLE;

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/scripts/upgrade/postgres/upgrade-2.0.0-to-2.1.0.postgres.sql
----------------------------------------------------------------------
diff --git a/metastore/scripts/upgrade/postgres/upgrade-2.0.0-to-2.1.0.postgres.sql b/metastore/scripts/upgrade/postgres/upgrade-2.0.0-to-2.1.0.postgres.sql
index 7fc603f..a7293f7 100644
--- a/metastore/scripts/upgrade/postgres/upgrade-2.0.0-to-2.1.0.postgres.sql
+++ b/metastore/scripts/upgrade/postgres/upgrade-2.0.0-to-2.1.0.postgres.sql
@@ -1,6 +1,5 @@
 SELECT 'Upgrading MetaStore schema from 2.0.0 to 2.1.0';
 
-\i 032-HIVE-12892.postgres.sql;
 \i 033-HIVE-13076.postgres.sql;
 \i 034-HIVE-13395.postgres.sql;
 


[4/5] hive git commit: HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)

Posted by se...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
index 2734a1c..29d9ec4 100644
--- a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
@@ -1240,14 +1240,14 @@ uint32_t ThriftHiveMetastore_get_databases_result::read(::apache::thrift::protoc
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size751;
-            ::apache::thrift::protocol::TType _etype754;
-            xfer += iprot->readListBegin(_etype754, _size751);
-            this->success.resize(_size751);
-            uint32_t _i755;
-            for (_i755 = 0; _i755 < _size751; ++_i755)
+            uint32_t _size747;
+            ::apache::thrift::protocol::TType _etype750;
+            xfer += iprot->readListBegin(_etype750, _size747);
+            this->success.resize(_size747);
+            uint32_t _i751;
+            for (_i751 = 0; _i751 < _size747; ++_i751)
             {
-              xfer += iprot->readString(this->success[_i755]);
+              xfer += iprot->readString(this->success[_i751]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1286,10 +1286,10 @@ uint32_t ThriftHiveMetastore_get_databases_result::write(::apache::thrift::proto
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter756;
-      for (_iter756 = this->success.begin(); _iter756 != this->success.end(); ++_iter756)
+      std::vector<std::string> ::const_iterator _iter752;
+      for (_iter752 = this->success.begin(); _iter752 != this->success.end(); ++_iter752)
       {
-        xfer += oprot->writeString((*_iter756));
+        xfer += oprot->writeString((*_iter752));
       }
       xfer += oprot->writeListEnd();
     }
@@ -1334,14 +1334,14 @@ uint32_t ThriftHiveMetastore_get_databases_presult::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size757;
-            ::apache::thrift::protocol::TType _etype760;
-            xfer += iprot->readListBegin(_etype760, _size757);
-            (*(this->success)).resize(_size757);
-            uint32_t _i761;
-            for (_i761 = 0; _i761 < _size757; ++_i761)
+            uint32_t _size753;
+            ::apache::thrift::protocol::TType _etype756;
+            xfer += iprot->readListBegin(_etype756, _size753);
+            (*(this->success)).resize(_size753);
+            uint32_t _i757;
+            for (_i757 = 0; _i757 < _size753; ++_i757)
             {
-              xfer += iprot->readString((*(this->success))[_i761]);
+              xfer += iprot->readString((*(this->success))[_i757]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1458,14 +1458,14 @@ uint32_t ThriftHiveMetastore_get_all_databases_result::read(::apache::thrift::pr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size762;
-            ::apache::thrift::protocol::TType _etype765;
-            xfer += iprot->readListBegin(_etype765, _size762);
-            this->success.resize(_size762);
-            uint32_t _i766;
-            for (_i766 = 0; _i766 < _size762; ++_i766)
+            uint32_t _size758;
+            ::apache::thrift::protocol::TType _etype761;
+            xfer += iprot->readListBegin(_etype761, _size758);
+            this->success.resize(_size758);
+            uint32_t _i762;
+            for (_i762 = 0; _i762 < _size758; ++_i762)
             {
-              xfer += iprot->readString(this->success[_i766]);
+              xfer += iprot->readString(this->success[_i762]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1504,10 +1504,10 @@ uint32_t ThriftHiveMetastore_get_all_databases_result::write(::apache::thrift::p
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter767;
-      for (_iter767 = this->success.begin(); _iter767 != this->success.end(); ++_iter767)
+      std::vector<std::string> ::const_iterator _iter763;
+      for (_iter763 = this->success.begin(); _iter763 != this->success.end(); ++_iter763)
       {
-        xfer += oprot->writeString((*_iter767));
+        xfer += oprot->writeString((*_iter763));
       }
       xfer += oprot->writeListEnd();
     }
@@ -1552,14 +1552,14 @@ uint32_t ThriftHiveMetastore_get_all_databases_presult::read(::apache::thrift::p
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size768;
-            ::apache::thrift::protocol::TType _etype771;
-            xfer += iprot->readListBegin(_etype771, _size768);
-            (*(this->success)).resize(_size768);
-            uint32_t _i772;
-            for (_i772 = 0; _i772 < _size768; ++_i772)
+            uint32_t _size764;
+            ::apache::thrift::protocol::TType _etype767;
+            xfer += iprot->readListBegin(_etype767, _size764);
+            (*(this->success)).resize(_size764);
+            uint32_t _i768;
+            for (_i768 = 0; _i768 < _size764; ++_i768)
             {
-              xfer += iprot->readString((*(this->success))[_i772]);
+              xfer += iprot->readString((*(this->success))[_i768]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2621,17 +2621,17 @@ uint32_t ThriftHiveMetastore_get_type_all_result::read(::apache::thrift::protoco
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->success.clear();
-            uint32_t _size773;
-            ::apache::thrift::protocol::TType _ktype774;
-            ::apache::thrift::protocol::TType _vtype775;
-            xfer += iprot->readMapBegin(_ktype774, _vtype775, _size773);
-            uint32_t _i777;
-            for (_i777 = 0; _i777 < _size773; ++_i777)
+            uint32_t _size769;
+            ::apache::thrift::protocol::TType _ktype770;
+            ::apache::thrift::protocol::TType _vtype771;
+            xfer += iprot->readMapBegin(_ktype770, _vtype771, _size769);
+            uint32_t _i773;
+            for (_i773 = 0; _i773 < _size769; ++_i773)
             {
-              std::string _key778;
-              xfer += iprot->readString(_key778);
-              Type& _val779 = this->success[_key778];
-              xfer += _val779.read(iprot);
+              std::string _key774;
+              xfer += iprot->readString(_key774);
+              Type& _val775 = this->success[_key774];
+              xfer += _val775.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2670,11 +2670,11 @@ uint32_t ThriftHiveMetastore_get_type_all_result::write(::apache::thrift::protoc
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_MAP, 0);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::map<std::string, Type> ::const_iterator _iter780;
-      for (_iter780 = this->success.begin(); _iter780 != this->success.end(); ++_iter780)
+      std::map<std::string, Type> ::const_iterator _iter776;
+      for (_iter776 = this->success.begin(); _iter776 != this->success.end(); ++_iter776)
       {
-        xfer += oprot->writeString(_iter780->first);
-        xfer += _iter780->second.write(oprot);
+        xfer += oprot->writeString(_iter776->first);
+        xfer += _iter776->second.write(oprot);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -2719,17 +2719,17 @@ uint32_t ThriftHiveMetastore_get_type_all_presult::read(::apache::thrift::protoc
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             (*(this->success)).clear();
-            uint32_t _size781;
-            ::apache::thrift::protocol::TType _ktype782;
-            ::apache::thrift::protocol::TType _vtype783;
-            xfer += iprot->readMapBegin(_ktype782, _vtype783, _size781);
-            uint32_t _i785;
-            for (_i785 = 0; _i785 < _size781; ++_i785)
+            uint32_t _size777;
+            ::apache::thrift::protocol::TType _ktype778;
+            ::apache::thrift::protocol::TType _vtype779;
+            xfer += iprot->readMapBegin(_ktype778, _vtype779, _size777);
+            uint32_t _i781;
+            for (_i781 = 0; _i781 < _size777; ++_i781)
             {
-              std::string _key786;
-              xfer += iprot->readString(_key786);
-              Type& _val787 = (*(this->success))[_key786];
-              xfer += _val787.read(iprot);
+              std::string _key782;
+              xfer += iprot->readString(_key782);
+              Type& _val783 = (*(this->success))[_key782];
+              xfer += _val783.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2883,14 +2883,14 @@ uint32_t ThriftHiveMetastore_get_fields_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size788;
-            ::apache::thrift::protocol::TType _etype791;
-            xfer += iprot->readListBegin(_etype791, _size788);
-            this->success.resize(_size788);
-            uint32_t _i792;
-            for (_i792 = 0; _i792 < _size788; ++_i792)
+            uint32_t _size784;
+            ::apache::thrift::protocol::TType _etype787;
+            xfer += iprot->readListBegin(_etype787, _size784);
+            this->success.resize(_size784);
+            uint32_t _i788;
+            for (_i788 = 0; _i788 < _size784; ++_i788)
             {
-              xfer += this->success[_i792].read(iprot);
+              xfer += this->success[_i788].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -2945,10 +2945,10 @@ uint32_t ThriftHiveMetastore_get_fields_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter793;
-      for (_iter793 = this->success.begin(); _iter793 != this->success.end(); ++_iter793)
+      std::vector<FieldSchema> ::const_iterator _iter789;
+      for (_iter789 = this->success.begin(); _iter789 != this->success.end(); ++_iter789)
       {
-        xfer += (*_iter793).write(oprot);
+        xfer += (*_iter789).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3001,14 +3001,14 @@ uint32_t ThriftHiveMetastore_get_fields_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size794;
-            ::apache::thrift::protocol::TType _etype797;
-            xfer += iprot->readListBegin(_etype797, _size794);
-            (*(this->success)).resize(_size794);
-            uint32_t _i798;
-            for (_i798 = 0; _i798 < _size794; ++_i798)
+            uint32_t _size790;
+            ::apache::thrift::protocol::TType _etype793;
+            xfer += iprot->readListBegin(_etype793, _size790);
+            (*(this->success)).resize(_size790);
+            uint32_t _i794;
+            for (_i794 = 0; _i794 < _size790; ++_i794)
             {
-              xfer += (*(this->success))[_i798].read(iprot);
+              xfer += (*(this->success))[_i794].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3194,14 +3194,14 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::read(::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size799;
-            ::apache::thrift::protocol::TType _etype802;
-            xfer += iprot->readListBegin(_etype802, _size799);
-            this->success.resize(_size799);
-            uint32_t _i803;
-            for (_i803 = 0; _i803 < _size799; ++_i803)
+            uint32_t _size795;
+            ::apache::thrift::protocol::TType _etype798;
+            xfer += iprot->readListBegin(_etype798, _size795);
+            this->success.resize(_size795);
+            uint32_t _i799;
+            for (_i799 = 0; _i799 < _size795; ++_i799)
             {
-              xfer += this->success[_i803].read(iprot);
+              xfer += this->success[_i799].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3256,10 +3256,10 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::write(:
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter804;
-      for (_iter804 = this->success.begin(); _iter804 != this->success.end(); ++_iter804)
+      std::vector<FieldSchema> ::const_iterator _iter800;
+      for (_iter800 = this->success.begin(); _iter800 != this->success.end(); ++_iter800)
       {
-        xfer += (*_iter804).write(oprot);
+        xfer += (*_iter800).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3312,14 +3312,14 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_presult::read(:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size805;
-            ::apache::thrift::protocol::TType _etype808;
-            xfer += iprot->readListBegin(_etype808, _size805);
-            (*(this->success)).resize(_size805);
-            uint32_t _i809;
-            for (_i809 = 0; _i809 < _size805; ++_i809)
+            uint32_t _size801;
+            ::apache::thrift::protocol::TType _etype804;
+            xfer += iprot->readListBegin(_etype804, _size801);
+            (*(this->success)).resize(_size801);
+            uint32_t _i805;
+            for (_i805 = 0; _i805 < _size801; ++_i805)
             {
-              xfer += (*(this->success))[_i809].read(iprot);
+              xfer += (*(this->success))[_i805].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3489,14 +3489,14 @@ uint32_t ThriftHiveMetastore_get_schema_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size810;
-            ::apache::thrift::protocol::TType _etype813;
-            xfer += iprot->readListBegin(_etype813, _size810);
-            this->success.resize(_size810);
-            uint32_t _i814;
-            for (_i814 = 0; _i814 < _size810; ++_i814)
+            uint32_t _size806;
+            ::apache::thrift::protocol::TType _etype809;
+            xfer += iprot->readListBegin(_etype809, _size806);
+            this->success.resize(_size806);
+            uint32_t _i810;
+            for (_i810 = 0; _i810 < _size806; ++_i810)
             {
-              xfer += this->success[_i814].read(iprot);
+              xfer += this->success[_i810].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3551,10 +3551,10 @@ uint32_t ThriftHiveMetastore_get_schema_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter815;
-      for (_iter815 = this->success.begin(); _iter815 != this->success.end(); ++_iter815)
+      std::vector<FieldSchema> ::const_iterator _iter811;
+      for (_iter811 = this->success.begin(); _iter811 != this->success.end(); ++_iter811)
       {
-        xfer += (*_iter815).write(oprot);
+        xfer += (*_iter811).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3607,14 +3607,14 @@ uint32_t ThriftHiveMetastore_get_schema_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size816;
-            ::apache::thrift::protocol::TType _etype819;
-            xfer += iprot->readListBegin(_etype819, _size816);
-            (*(this->success)).resize(_size816);
-            uint32_t _i820;
-            for (_i820 = 0; _i820 < _size816; ++_i820)
+            uint32_t _size812;
+            ::apache::thrift::protocol::TType _etype815;
+            xfer += iprot->readListBegin(_etype815, _size812);
+            (*(this->success)).resize(_size812);
+            uint32_t _i816;
+            for (_i816 = 0; _i816 < _size812; ++_i816)
             {
-              xfer += (*(this->success))[_i820].read(iprot);
+              xfer += (*(this->success))[_i816].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3800,14 +3800,14 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::read(::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size821;
-            ::apache::thrift::protocol::TType _etype824;
-            xfer += iprot->readListBegin(_etype824, _size821);
-            this->success.resize(_size821);
-            uint32_t _i825;
-            for (_i825 = 0; _i825 < _size821; ++_i825)
+            uint32_t _size817;
+            ::apache::thrift::protocol::TType _etype820;
+            xfer += iprot->readListBegin(_etype820, _size817);
+            this->success.resize(_size817);
+            uint32_t _i821;
+            for (_i821 = 0; _i821 < _size817; ++_i821)
             {
-              xfer += this->success[_i825].read(iprot);
+              xfer += this->success[_i821].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3862,10 +3862,10 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::write(:
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter826;
-      for (_iter826 = this->success.begin(); _iter826 != this->success.end(); ++_iter826)
+      std::vector<FieldSchema> ::const_iterator _iter822;
+      for (_iter822 = this->success.begin(); _iter822 != this->success.end(); ++_iter822)
       {
-        xfer += (*_iter826).write(oprot);
+        xfer += (*_iter822).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3918,14 +3918,14 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_presult::read(:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size827;
-            ::apache::thrift::protocol::TType _etype830;
-            xfer += iprot->readListBegin(_etype830, _size827);
-            (*(this->success)).resize(_size827);
-            uint32_t _i831;
-            for (_i831 = 0; _i831 < _size827; ++_i831)
+            uint32_t _size823;
+            ::apache::thrift::protocol::TType _etype826;
+            xfer += iprot->readListBegin(_etype826, _size823);
+            (*(this->success)).resize(_size823);
+            uint32_t _i827;
+            for (_i827 = 0; _i827 < _size823; ++_i827)
             {
-              xfer += (*(this->success))[_i831].read(iprot);
+              xfer += (*(this->success))[_i827].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -4518,14 +4518,14 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_args::read(::apache::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->primaryKeys.clear();
-            uint32_t _size832;
-            ::apache::thrift::protocol::TType _etype835;
-            xfer += iprot->readListBegin(_etype835, _size832);
-            this->primaryKeys.resize(_size832);
-            uint32_t _i836;
-            for (_i836 = 0; _i836 < _size832; ++_i836)
+            uint32_t _size828;
+            ::apache::thrift::protocol::TType _etype831;
+            xfer += iprot->readListBegin(_etype831, _size828);
+            this->primaryKeys.resize(_size828);
+            uint32_t _i832;
+            for (_i832 = 0; _i832 < _size828; ++_i832)
             {
-              xfer += this->primaryKeys[_i836].read(iprot);
+              xfer += this->primaryKeys[_i832].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -4538,14 +4538,14 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_args::read(::apache::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->foreignKeys.clear();
-            uint32_t _size837;
-            ::apache::thrift::protocol::TType _etype840;
-            xfer += iprot->readListBegin(_etype840, _size837);
-            this->foreignKeys.resize(_size837);
-            uint32_t _i841;
-            for (_i841 = 0; _i841 < _size837; ++_i841)
+            uint32_t _size833;
+            ::apache::thrift::protocol::TType _etype836;
+            xfer += iprot->readListBegin(_etype836, _size833);
+            this->foreignKeys.resize(_size833);
+            uint32_t _i837;
+            for (_i837 = 0; _i837 < _size833; ++_i837)
             {
-              xfer += this->foreignKeys[_i841].read(iprot);
+              xfer += this->foreignKeys[_i837].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -4578,10 +4578,10 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_args::write(::apache:
   xfer += oprot->writeFieldBegin("primaryKeys", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->primaryKeys.size()));
-    std::vector<SQLPrimaryKey> ::const_iterator _iter842;
-    for (_iter842 = this->primaryKeys.begin(); _iter842 != this->primaryKeys.end(); ++_iter842)
+    std::vector<SQLPrimaryKey> ::const_iterator _iter838;
+    for (_iter838 = this->primaryKeys.begin(); _iter838 != this->primaryKeys.end(); ++_iter838)
     {
-      xfer += (*_iter842).write(oprot);
+      xfer += (*_iter838).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -4590,10 +4590,10 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_args::write(::apache:
   xfer += oprot->writeFieldBegin("foreignKeys", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->foreignKeys.size()));
-    std::vector<SQLForeignKey> ::const_iterator _iter843;
-    for (_iter843 = this->foreignKeys.begin(); _iter843 != this->foreignKeys.end(); ++_iter843)
+    std::vector<SQLForeignKey> ::const_iterator _iter839;
+    for (_iter839 = this->foreignKeys.begin(); _iter839 != this->foreignKeys.end(); ++_iter839)
     {
-      xfer += (*_iter843).write(oprot);
+      xfer += (*_iter839).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -4621,10 +4621,10 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_pargs::write(::apache
   xfer += oprot->writeFieldBegin("primaryKeys", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>((*(this->primaryKeys)).size()));
-    std::vector<SQLPrimaryKey> ::const_iterator _iter844;
-    for (_iter844 = (*(this->primaryKeys)).begin(); _iter844 != (*(this->primaryKeys)).end(); ++_iter844)
+    std::vector<SQLPrimaryKey> ::const_iterator _iter840;
+    for (_iter840 = (*(this->primaryKeys)).begin(); _iter840 != (*(this->primaryKeys)).end(); ++_iter840)
     {
-      xfer += (*_iter844).write(oprot);
+      xfer += (*_iter840).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -4633,10 +4633,10 @@ uint32_t ThriftHiveMetastore_create_table_with_constraints_pargs::write(::apache
   xfer += oprot->writeFieldBegin("foreignKeys", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>((*(this->foreignKeys)).size()));
-    std::vector<SQLForeignKey> ::const_iterator _iter845;
-    for (_iter845 = (*(this->foreignKeys)).begin(); _iter845 != (*(this->foreignKeys)).end(); ++_iter845)
+    std::vector<SQLForeignKey> ::const_iterator _iter841;
+    for (_iter841 = (*(this->foreignKeys)).begin(); _iter841 != (*(this->foreignKeys)).end(); ++_iter841)
     {
-      xfer += (*_iter845).write(oprot);
+      xfer += (*_iter841).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -5641,14 +5641,14 @@ uint32_t ThriftHiveMetastore_get_tables_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size846;
-            ::apache::thrift::protocol::TType _etype849;
-            xfer += iprot->readListBegin(_etype849, _size846);
-            this->success.resize(_size846);
-            uint32_t _i850;
-            for (_i850 = 0; _i850 < _size846; ++_i850)
+            uint32_t _size842;
+            ::apache::thrift::protocol::TType _etype845;
+            xfer += iprot->readListBegin(_etype845, _size842);
+            this->success.resize(_size842);
+            uint32_t _i846;
+            for (_i846 = 0; _i846 < _size842; ++_i846)
             {
-              xfer += iprot->readString(this->success[_i850]);
+              xfer += iprot->readString(this->success[_i846]);
             }
             xfer += iprot->readListEnd();
           }
@@ -5687,10 +5687,10 @@ uint32_t ThriftHiveMetastore_get_tables_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter851;
-      for (_iter851 = this->success.begin(); _iter851 != this->success.end(); ++_iter851)
+      std::vector<std::string> ::const_iterator _iter847;
+      for (_iter847 = this->success.begin(); _iter847 != this->success.end(); ++_iter847)
       {
-        xfer += oprot->writeString((*_iter851));
+        xfer += oprot->writeString((*_iter847));
       }
       xfer += oprot->writeListEnd();
     }
@@ -5735,14 +5735,14 @@ uint32_t ThriftHiveMetastore_get_tables_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size852;
-            ::apache::thrift::protocol::TType _etype855;
-            xfer += iprot->readListBegin(_etype855, _size852);
-            (*(this->success)).resize(_size852);
-            uint32_t _i856;
-            for (_i856 = 0; _i856 < _size852; ++_i856)
+            uint32_t _size848;
+            ::apache::thrift::protocol::TType _etype851;
+            xfer += iprot->readListBegin(_etype851, _size848);
+            (*(this->success)).resize(_size848);
+            uint32_t _i852;
+            for (_i852 = 0; _i852 < _size848; ++_i852)
             {
-              xfer += iprot->readString((*(this->success))[_i856]);
+              xfer += iprot->readString((*(this->success))[_i852]);
             }
             xfer += iprot->readListEnd();
           }
@@ -5817,14 +5817,14 @@ uint32_t ThriftHiveMetastore_get_table_meta_args::read(::apache::thrift::protoco
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->tbl_types.clear();
-            uint32_t _size857;
-            ::apache::thrift::protocol::TType _etype860;
-            xfer += iprot->readListBegin(_etype860, _size857);
-            this->tbl_types.resize(_size857);
-            uint32_t _i861;
-            for (_i861 = 0; _i861 < _size857; ++_i861)
+            uint32_t _size853;
+            ::apache::thrift::protocol::TType _etype856;
+            xfer += iprot->readListBegin(_etype856, _size853);
+            this->tbl_types.resize(_size853);
+            uint32_t _i857;
+            for (_i857 = 0; _i857 < _size853; ++_i857)
             {
-              xfer += iprot->readString(this->tbl_types[_i861]);
+              xfer += iprot->readString(this->tbl_types[_i857]);
             }
             xfer += iprot->readListEnd();
           }
@@ -5861,10 +5861,10 @@ uint32_t ThriftHiveMetastore_get_table_meta_args::write(::apache::thrift::protoc
   xfer += oprot->writeFieldBegin("tbl_types", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->tbl_types.size()));
-    std::vector<std::string> ::const_iterator _iter862;
-    for (_iter862 = this->tbl_types.begin(); _iter862 != this->tbl_types.end(); ++_iter862)
+    std::vector<std::string> ::const_iterator _iter858;
+    for (_iter858 = this->tbl_types.begin(); _iter858 != this->tbl_types.end(); ++_iter858)
     {
-      xfer += oprot->writeString((*_iter862));
+      xfer += oprot->writeString((*_iter858));
     }
     xfer += oprot->writeListEnd();
   }
@@ -5896,10 +5896,10 @@ uint32_t ThriftHiveMetastore_get_table_meta_pargs::write(::apache::thrift::proto
   xfer += oprot->writeFieldBegin("tbl_types", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->tbl_types)).size()));
-    std::vector<std::string> ::const_iterator _iter863;
-    for (_iter863 = (*(this->tbl_types)).begin(); _iter863 != (*(this->tbl_types)).end(); ++_iter863)
+    std::vector<std::string> ::const_iterator _iter859;
+    for (_iter859 = (*(this->tbl_types)).begin(); _iter859 != (*(this->tbl_types)).end(); ++_iter859)
     {
-      xfer += oprot->writeString((*_iter863));
+      xfer += oprot->writeString((*_iter859));
     }
     xfer += oprot->writeListEnd();
   }
@@ -5940,14 +5940,14 @@ uint32_t ThriftHiveMetastore_get_table_meta_result::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size864;
-            ::apache::thrift::protocol::TType _etype867;
-            xfer += iprot->readListBegin(_etype867, _size864);
-            this->success.resize(_size864);
-            uint32_t _i868;
-            for (_i868 = 0; _i868 < _size864; ++_i868)
+            uint32_t _size860;
+            ::apache::thrift::protocol::TType _etype863;
+            xfer += iprot->readListBegin(_etype863, _size860);
+            this->success.resize(_size860);
+            uint32_t _i864;
+            for (_i864 = 0; _i864 < _size860; ++_i864)
             {
-              xfer += this->success[_i868].read(iprot);
+              xfer += this->success[_i864].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -5986,10 +5986,10 @@ uint32_t ThriftHiveMetastore_get_table_meta_result::write(::apache::thrift::prot
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<TableMeta> ::const_iterator _iter869;
-      for (_iter869 = this->success.begin(); _iter869 != this->success.end(); ++_iter869)
+      std::vector<TableMeta> ::const_iterator _iter865;
+      for (_iter865 = this->success.begin(); _iter865 != this->success.end(); ++_iter865)
       {
-        xfer += (*_iter869).write(oprot);
+        xfer += (*_iter865).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -6034,14 +6034,14 @@ uint32_t ThriftHiveMetastore_get_table_meta_presult::read(::apache::thrift::prot
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size870;
-            ::apache::thrift::protocol::TType _etype873;
-            xfer += iprot->readListBegin(_etype873, _size870);
-            (*(this->success)).resize(_size870);
-            uint32_t _i874;
-            for (_i874 = 0; _i874 < _size870; ++_i874)
+            uint32_t _size866;
+            ::apache::thrift::protocol::TType _etype869;
+            xfer += iprot->readListBegin(_etype869, _size866);
+            (*(this->success)).resize(_size866);
+            uint32_t _i870;
+            for (_i870 = 0; _i870 < _size866; ++_i870)
             {
-              xfer += (*(this->success))[_i874].read(iprot);
+              xfer += (*(this->success))[_i870].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -6179,14 +6179,14 @@ uint32_t ThriftHiveMetastore_get_all_tables_result::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size875;
-            ::apache::thrift::protocol::TType _etype878;
-            xfer += iprot->readListBegin(_etype878, _size875);
-            this->success.resize(_size875);
-            uint32_t _i879;
-            for (_i879 = 0; _i879 < _size875; ++_i879)
+            uint32_t _size871;
+            ::apache::thrift::protocol::TType _etype874;
+            xfer += iprot->readListBegin(_etype874, _size871);
+            this->success.resize(_size871);
+            uint32_t _i875;
+            for (_i875 = 0; _i875 < _size871; ++_i875)
             {
-              xfer += iprot->readString(this->success[_i879]);
+              xfer += iprot->readString(this->success[_i875]);
             }
             xfer += iprot->readListEnd();
           }
@@ -6225,10 +6225,10 @@ uint32_t ThriftHiveMetastore_get_all_tables_result::write(::apache::thrift::prot
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter880;
-      for (_iter880 = this->success.begin(); _iter880 != this->success.end(); ++_iter880)
+      std::vector<std::string> ::const_iterator _iter876;
+      for (_iter876 = this->success.begin(); _iter876 != this->success.end(); ++_iter876)
       {
-        xfer += oprot->writeString((*_iter880));
+        xfer += oprot->writeString((*_iter876));
       }
       xfer += oprot->writeListEnd();
     }
@@ -6273,14 +6273,14 @@ uint32_t ThriftHiveMetastore_get_all_tables_presult::read(::apache::thrift::prot
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size881;
-            ::apache::thrift::protocol::TType _etype884;
-            xfer += iprot->readListBegin(_etype884, _size881);
-            (*(this->success)).resize(_size881);
-            uint32_t _i885;
-            for (_i885 = 0; _i885 < _size881; ++_i885)
+            uint32_t _size877;
+            ::apache::thrift::protocol::TType _etype880;
+            xfer += iprot->readListBegin(_etype880, _size877);
+            (*(this->success)).resize(_size877);
+            uint32_t _i881;
+            for (_i881 = 0; _i881 < _size877; ++_i881)
             {
-              xfer += iprot->readString((*(this->success))[_i885]);
+              xfer += iprot->readString((*(this->success))[_i881]);
             }
             xfer += iprot->readListEnd();
           }
@@ -6590,14 +6590,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::read(::apache::thri
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->tbl_names.clear();
-            uint32_t _size886;
-            ::apache::thrift::protocol::TType _etype889;
-            xfer += iprot->readListBegin(_etype889, _size886);
-            this->tbl_names.resize(_size886);
-            uint32_t _i890;
-            for (_i890 = 0; _i890 < _size886; ++_i890)
+            uint32_t _size882;
+            ::apache::thrift::protocol::TType _etype885;
+            xfer += iprot->readListBegin(_etype885, _size882);
+            this->tbl_names.resize(_size882);
+            uint32_t _i886;
+            for (_i886 = 0; _i886 < _size882; ++_i886)
             {
-              xfer += iprot->readString(this->tbl_names[_i890]);
+              xfer += iprot->readString(this->tbl_names[_i886]);
             }
             xfer += iprot->readListEnd();
           }
@@ -6630,10 +6630,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::write(::apache::thr
   xfer += oprot->writeFieldBegin("tbl_names", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->tbl_names.size()));
-    std::vector<std::string> ::const_iterator _iter891;
-    for (_iter891 = this->tbl_names.begin(); _iter891 != this->tbl_names.end(); ++_iter891)
+    std::vector<std::string> ::const_iterator _iter887;
+    for (_iter887 = this->tbl_names.begin(); _iter887 != this->tbl_names.end(); ++_iter887)
     {
-      xfer += oprot->writeString((*_iter891));
+      xfer += oprot->writeString((*_iter887));
     }
     xfer += oprot->writeListEnd();
   }
@@ -6661,10 +6661,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_pargs::write(::apache::th
   xfer += oprot->writeFieldBegin("tbl_names", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->tbl_names)).size()));
-    std::vector<std::string> ::const_iterator _iter892;
-    for (_iter892 = (*(this->tbl_names)).begin(); _iter892 != (*(this->tbl_names)).end(); ++_iter892)
+    std::vector<std::string> ::const_iterator _iter888;
+    for (_iter888 = (*(this->tbl_names)).begin(); _iter888 != (*(this->tbl_names)).end(); ++_iter888)
     {
-      xfer += oprot->writeString((*_iter892));
+      xfer += oprot->writeString((*_iter888));
     }
     xfer += oprot->writeListEnd();
   }
@@ -6705,14 +6705,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::read(::apache::th
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size893;
-            ::apache::thrift::protocol::TType _etype896;
-            xfer += iprot->readListBegin(_etype896, _size893);
-            this->success.resize(_size893);
-            uint32_t _i897;
-            for (_i897 = 0; _i897 < _size893; ++_i897)
+            uint32_t _size889;
+            ::apache::thrift::protocol::TType _etype892;
+            xfer += iprot->readListBegin(_etype892, _size889);
+            this->success.resize(_size889);
+            uint32_t _i893;
+            for (_i893 = 0; _i893 < _size889; ++_i893)
             {
-              xfer += this->success[_i897].read(iprot);
+              xfer += this->success[_i893].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -6767,10 +6767,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::write(::apache::t
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<Table> ::const_iterator _iter898;
-      for (_iter898 = this->success.begin(); _iter898 != this->success.end(); ++_iter898)
+      std::vector<Table> ::const_iterator _iter894;
+      for (_iter894 = this->success.begin(); _iter894 != this->success.end(); ++_iter894)
       {
-        xfer += (*_iter898).write(oprot);
+        xfer += (*_iter894).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -6823,14 +6823,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_presult::read(::apache::t
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size899;
-            ::apache::thrift::protocol::TType _etype902;
-            xfer += iprot->readListBegin(_etype902, _size899);
-            (*(this->success)).resize(_size899);
-            uint32_t _i903;
-            for (_i903 = 0; _i903 < _size899; ++_i903)
+            uint32_t _size895;
+            ::apache::thrift::protocol::TType _etype898;
+            xfer += iprot->readListBegin(_etype898, _size895);
+            (*(this->success)).resize(_size895);
+            uint32_t _i899;
+            for (_i899 = 0; _i899 < _size895; ++_i899)
             {
-              xfer += (*(this->success))[_i903].read(iprot);
+              xfer += (*(this->success))[_i899].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -7016,14 +7016,14 @@ uint32_t ThriftHiveMetastore_get_table_names_by_filter_result::read(::apache::th
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size904;
-            ::apache::thrift::protocol::TType _etype907;
-            xfer += iprot->readListBegin(_etype907, _size904);
-            this->success.resize(_size904);
-            uint32_t _i908;
-            for (_i908 = 0; _i908 < _size904; ++_i908)
+            uint32_t _size900;
+            ::apache::thrift::protocol::TType _etype903;
+            xfer += iprot->readListBegin(_etype903, _size900);
+            this->success.resize(_size900);
+            uint32_t _i904;
+            for (_i904 = 0; _i904 < _size900; ++_i904)
             {
-              xfer += iprot->readString(this->success[_i908]);
+              xfer += iprot->readString(this->success[_i904]);
             }
             xfer += iprot->readListEnd();
           }
@@ -7078,10 +7078,10 @@ uint32_t ThriftHiveMetastore_get_table_names_by_filter_result::write(::apache::t
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter909;
-      for (_iter909 = this->success.begin(); _iter909 != this->success.end(); ++_iter909)
+      std::vector<std::string> ::const_iterator _iter905;
+      for (_iter905 = this->success.begin(); _iter905 != this->success.end(); ++_iter905)
       {
-        xfer += oprot->writeString((*_iter909));
+        xfer += oprot->writeString((*_iter905));
       }
       xfer += oprot->writeListEnd();
     }
@@ -7134,14 +7134,14 @@ uint32_t ThriftHiveMetastore_get_table_names_by_filter_presult::read(::apache::t
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size910;
-            ::apache::thrift::protocol::TType _etype913;
-            xfer += iprot->readListBegin(_etype913, _size910);
-            (*(this->success)).resize(_size910);
-            uint32_t _i914;
-            for (_i914 = 0; _i914 < _size910; ++_i914)
+            uint32_t _size906;
+            ::apache::thrift::protocol::TType _etype909;
+            xfer += iprot->readListBegin(_etype909, _size906);
+            (*(this->success)).resize(_size906);
+            uint32_t _i910;
+            for (_i910 = 0; _i910 < _size906; ++_i910)
             {
-              xfer += iprot->readString((*(this->success))[_i914]);
+              xfer += iprot->readString((*(this->success))[_i910]);
             }
             xfer += iprot->readListEnd();
           }
@@ -8475,14 +8475,14 @@ uint32_t ThriftHiveMetastore_add_partitions_args::read(::apache::thrift::protoco
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->new_parts.clear();
-            uint32_t _size915;
-            ::apache::thrift::protocol::TType _etype918;
-            xfer += iprot->readListBegin(_etype918, _size915);
-            this->new_parts.resize(_size915);
-            uint32_t _i919;
-            for (_i919 = 0; _i919 < _size915; ++_i919)
+            uint32_t _size911;
+            ::apache::thrift::protocol::TType _etype914;
+            xfer += iprot->readListBegin(_etype914, _size911);
+            this->new_parts.resize(_size911);
+            uint32_t _i915;
+            for (_i915 = 0; _i915 < _size911; ++_i915)
             {
-              xfer += this->new_parts[_i919].read(iprot);
+              xfer += this->new_parts[_i915].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -8511,10 +8511,10 @@ uint32_t ThriftHiveMetastore_add_partitions_args::write(::apache::thrift::protoc
   xfer += oprot->writeFieldBegin("new_parts", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->new_parts.size()));
-    std::vector<Partition> ::const_iterator _iter920;
-    for (_iter920 = this->new_parts.begin(); _iter920 != this->new_parts.end(); ++_iter920)
+    std::vector<Partition> ::const_iterator _iter916;
+    for (_iter916 = this->new_parts.begin(); _iter916 != this->new_parts.end(); ++_iter916)
     {
-      xfer += (*_iter920).write(oprot);
+      xfer += (*_iter916).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -8538,10 +8538,10 @@ uint32_t ThriftHiveMetastore_add_partitions_pargs::write(::apache::thrift::proto
   xfer += oprot->writeFieldBegin("new_parts", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>((*(this->new_parts)).size()));
-    std::vector<Partition> ::const_iterator _iter921;
-    for (_iter921 = (*(this->new_parts)).begin(); _iter921 != (*(this->new_parts)).end(); ++_iter921)
+    std::vector<Partition> ::const_iterator _iter917;
+    for (_iter917 = (*(this->new_parts)).begin(); _iter917 != (*(this->new_parts)).end(); ++_iter917)
     {
-      xfer += (*_iter921).write(oprot);
+      xfer += (*_iter917).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -8750,14 +8750,14 @@ uint32_t ThriftHiveMetastore_add_partitions_pspec_args::read(::apache::thrift::p
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->new_parts.clear();
-            uint32_t _size922;
-            ::apache::thrift::protocol::TType _etype925;
-            xfer += iprot->readListBegin(_etype925, _size922);
-            this->new_parts.resize(_size922);
-            uint32_t _i926;
-            for (_i926 = 0; _i926 < _size922; ++_i926)
+            uint32_t _size918;
+            ::apache::thrift::protocol::TType _etype921;
+            xfer += iprot->readListBegin(_etype921, _size918);
+            this->new_parts.resize(_size918);
+            uint32_t _i922;
+            for (_i922 = 0; _i922 < _size918; ++_i922)
             {
-              xfer += this->new_parts[_i926].read(iprot);
+              xfer += this->new_parts[_i922].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -8786,10 +8786,10 @@ uint32_t ThriftHiveMetastore_add_partitions_pspec_args::write(::apache::thrift::
   xfer += oprot->writeFieldBegin("new_parts", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->new_parts.size()));
-    std::vector<PartitionSpec> ::const_iterator _iter927;
-    for (_iter927 = this->new_parts.begin(); _iter927 != this->new_parts.end(); ++_iter927)
+    std::vector<PartitionSpec> ::const_iterator _iter923;
+    for (_iter923 = this->new_parts.begin(); _iter923 != this->new_parts.end(); ++_iter923)
     {
-      xfer += (*_iter927).write(oprot);
+      xfer += (*_iter923).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -8813,10 +8813,10 @@ uint32_t ThriftHiveMetastore_add_partitions_pspec_pargs::write(::apache::thrift:
   xfer += oprot->writeFieldBegin("new_parts", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>((*(this->new_parts)).size()));
-    std::vector<PartitionSpec> ::const_iterator _iter928;
-    for (_iter928 = (*(this->new_parts)).begin(); _iter928 != (*(this->new_parts)).end(); ++_iter928)
+    std::vector<PartitionSpec> ::const_iterator _iter924;
+    for (_iter924 = (*(this->new_parts)).begin(); _iter924 != (*(this->new_parts)).end(); ++_iter924)
     {
-      xfer += (*_iter928).write(oprot);
+      xfer += (*_iter924).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -9041,14 +9041,14 @@ uint32_t ThriftHiveMetastore_append_partition_args::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size929;
-            ::apache::thrift::protocol::TType _etype932;
-            xfer += iprot->readListBegin(_etype932, _size929);
-            this->part_vals.resize(_size929);
-            uint32_t _i933;
-            for (_i933 = 0; _i933 < _size929; ++_i933)
+            uint32_t _size925;
+            ::apache::thrift::protocol::TType _etype928;
+            xfer += iprot->readListBegin(_etype928, _size925);
+            this->part_vals.resize(_size925);
+            uint32_t _i929;
+            for (_i929 = 0; _i929 < _size925; ++_i929)
             {
-              xfer += iprot->readString(this->part_vals[_i933]);
+              xfer += iprot->readString(this->part_vals[_i929]);
             }
             xfer += iprot->readListEnd();
           }
@@ -9085,10 +9085,10 @@ uint32_t ThriftHiveMetastore_append_partition_args::write(::apache::thrift::prot
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter934;
-    for (_iter934 = this->part_vals.begin(); _iter934 != this->part_vals.end(); ++_iter934)
+    std::vector<std::string> ::const_iterator _iter930;
+    for (_iter930 = this->part_vals.begin(); _iter930 != this->part_vals.end(); ++_iter930)
     {
-      xfer += oprot->writeString((*_iter934));
+      xfer += oprot->writeString((*_iter930));
     }
     xfer += oprot->writeListEnd();
   }
@@ -9120,10 +9120,10 @@ uint32_t ThriftHiveMetastore_append_partition_pargs::write(::apache::thrift::pro
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter935;
-    for (_iter935 = (*(this->part_vals)).begin(); _iter935 != (*(this->part_vals)).end(); ++_iter935)
+    std::vector<std::string> ::const_iterator _iter931;
+    for (_iter931 = (*(this->part_vals)).begin(); _iter931 != (*(this->part_vals)).end(); ++_iter931)
     {
-      xfer += oprot->writeString((*_iter935));
+      xfer += oprot->writeString((*_iter931));
     }
     xfer += oprot->writeListEnd();
   }
@@ -9595,14 +9595,14 @@ uint32_t ThriftHiveMetastore_append_partition_with_environment_context_args::rea
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size936;
-            ::apache::thrift::protocol::TType _etype939;
-            xfer += iprot->readListBegin(_etype939, _size936);
-            this->part_vals.resize(_size936);
-            uint32_t _i940;
-            for (_i940 = 0; _i940 < _size936; ++_i940)
+            uint32_t _size932;
+            ::apache::thrift::protocol::TType _etype935;
+            xfer += iprot->readListBegin(_etype935, _size932);
+            this->part_vals.resize(_size932);
+            uint32_t _i936;
+            for (_i936 = 0; _i936 < _size932; ++_i936)
             {
-              xfer += iprot->readString(this->part_vals[_i940]);
+              xfer += iprot->readString(this->part_vals[_i936]);
             }
             xfer += iprot->readListEnd();
           }
@@ -9647,10 +9647,10 @@ uint32_t ThriftHiveMetastore_append_partition_with_environment_context_args::wri
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter941;
-    for (_iter941 = this->part_vals.begin(); _iter941 != this->part_vals.end(); ++_iter941)
+    std::vector<std::string> ::const_iterator _iter937;
+    for (_iter937 = this->part_vals.begin(); _iter937 != this->part_vals.end(); ++_iter937)
     {
-      xfer += oprot->writeString((*_iter941));
+      xfer += oprot->writeString((*_iter937));
     }
     xfer += oprot->writeListEnd();
   }
@@ -9686,10 +9686,10 @@ uint32_t ThriftHiveMetastore_append_partition_with_environment_context_pargs::wr
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter942;
-    for (_iter942 = (*(this->part_vals)).begin(); _iter942 != (*(this->part_vals)).end(); ++_iter942)
+    std::vector<std::string> ::const_iterator _iter938;
+    for (_iter938 = (*(this->part_vals)).begin(); _iter938 != (*(this->part_vals)).end(); ++_iter938)
     {
-      xfer += oprot->writeString((*_iter942));
+      xfer += oprot->writeString((*_iter938));
     }
     xfer += oprot->writeListEnd();
   }
@@ -10492,14 +10492,14 @@ uint32_t ThriftHiveMetastore_drop_partition_args::read(::apache::thrift::protoco
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size943;
-            ::apache::thrift::protocol::TType _etype946;
-            xfer += iprot->readListBegin(_etype946, _size943);
-            this->part_vals.resize(_size943);
-            uint32_t _i947;
-            for (_i947 = 0; _i947 < _size943; ++_i947)
+            uint32_t _size939;
+            ::apache::thrift::protocol::TType _etype942;
+            xfer += iprot->readListBegin(_etype942, _size939);
+            this->part_vals.resize(_size939);
+            uint32_t _i943;
+            for (_i943 = 0; _i943 < _size939; ++_i943)
             {
-              xfer += iprot->readString(this->part_vals[_i947]);
+              xfer += iprot->readString(this->part_vals[_i943]);
             }
             xfer += iprot->readListEnd();
           }
@@ -10544,10 +10544,10 @@ uint32_t ThriftHiveMetastore_drop_partition_args::write(::apache::thrift::protoc
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter948;
-    for (_iter948 = this->part_vals.begin(); _iter948 != this->part_vals.end(); ++_iter948)
+    std::vector<std::string> ::const_iterator _iter944;
+    for (_iter944 = this->part_vals.begin(); _iter944 != this->part_vals.end(); ++_iter944)
     {
-      xfer += oprot->writeString((*_iter948));
+      xfer += oprot->writeString((*_iter944));
     }
     xfer += oprot->writeListEnd();
   }
@@ -10583,10 +10583,10 @@ uint32_t ThriftHiveMetastore_drop_partition_pargs::write(::apache::thrift::proto
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter949;
-    for (_iter949 = (*(this->part_vals)).begin(); _iter949 != (*(this->part_vals)).end(); ++_iter949)
+    std::vector<std::string> ::const_iterator _iter945;
+    for (_iter945 = (*(this->part_vals)).begin(); _iter945 != (*(this->part_vals)).end(); ++_iter945)
     {
-      xfer += oprot->writeString((*_iter949));
+      xfer += oprot->writeString((*_iter945));
     }
     xfer += oprot->writeListEnd();
   }
@@ -10795,14 +10795,14 @@ uint32_t ThriftHiveMetastore_drop_partition_with_environment_context_args::read(
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size950;
-            ::apache::thrift::protocol::TType _etype953;
-            xfer += iprot->readListBegin(_etype953, _size950);
-            this->part_vals.resize(_size950);
-            uint32_t _i954;
-            for (_i954 = 0; _i954 < _size950; ++_i954)
+            uint32_t _size946;
+            ::apache::thrift::protocol::TType _etype949;
+            xfer += iprot->readListBegin(_etype949, _size946);
+            this->part_vals.resize(_size946);
+            uint32_t _i950;
+            for (_i950 = 0; _i950 < _size946; ++_i950)
             {
-              xfer += iprot->readString(this->part_vals[_i954]);
+              xfer += iprot->readString(this->part_vals[_i950]);
             }
             xfer += iprot->readListEnd();
           }
@@ -10855,10 +10855,10 @@ uint32_t ThriftHiveMetastore_drop_partition_with_environment_context_args::write
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter955;
-    for (_iter955 = this->part_vals.begin(); _iter955 != this->part_vals.end(); ++_iter955)
+    std::vector<std::string> ::const_iterator _iter951;
+    for (_iter951 = this->part_vals.begin(); _iter951 != this->part_vals.end(); ++_iter951)
     {
-      xfer += oprot->writeString((*_iter955));
+      xfer += oprot->writeString((*_iter951));
     }
     xfer += oprot->writeListEnd();
   }
@@ -10898,10 +10898,10 @@ uint32_t ThriftHiveMetastore_drop_partition_with_environment_context_pargs::writ
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter956;
-    for (_iter956 = (*(this->part_vals)).begin(); _iter956 != (*(this->part_vals)).end(); ++_iter956)
+    std::vector<std::string> ::const_iterator _iter952;
+    for (_iter952 = (*(this->part_vals)).begin(); _iter952 != (*(this->part_vals)).end(); ++_iter952)
     {
-      xfer += oprot->writeString((*_iter956));
+      xfer += oprot->writeString((*_iter952));
     }
     xfer += oprot->writeListEnd();
   }
@@ -11907,14 +11907,14 @@ uint32_t ThriftHiveMetastore_get_partition_args::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size957;
-            ::apache::thrift::protocol::TType _etype960;
-            xfer += iprot->readListBegin(_etype960, _size957);
-            this->part_vals.resize(_size957);
-            uint32_t _i961;
-            for (_i961 = 0; _i961 < _size957; ++_i961)
+            uint32_t _size953;
+            ::apache::thrift::protocol::TType _etype956;
+            xfer += iprot->readListBegin(_etype956, _size953);
+            this->part_vals.resize(_size953);
+            uint32_t _i957;
+            for (_i957 = 0; _i957 < _size953; ++_i957)
             {
-              xfer += iprot->readString(this->part_vals[_i961]);
+              xfer += iprot->readString(this->part_vals[_i957]);
             }
             xfer += iprot->readListEnd();
           }
@@ -11951,10 +11951,10 @@ uint32_t ThriftHiveMetastore_get_partition_args::write(::apache::thrift::protoco
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter962;
-    for (_iter962 = this->part_vals.begin(); _iter962 != this->part_vals.end(); ++_iter962)
+    std::vector<std::string> ::const_iterator _iter958;
+    for (_iter958 = this->part_vals.begin(); _iter958 != this->part_vals.end(); ++_iter958)
     {
-      xfer += oprot->writeString((*_iter962));
+      xfer += oprot->writeString((*_iter958));
     }
     xfer += oprot->writeListEnd();
   }
@@ -11986,10 +11986,10 @@ uint32_t ThriftHiveMetastore_get_partition_pargs::write(::apache::thrift::protoc
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter963;
-    for (_iter963 = (*(this->part_vals)).begin(); _iter963 != (*(this->part_vals)).end(); ++_iter963)
+    std::vector<std::string> ::const_iterator _iter959;
+    for (_iter959 = (*(this->part_vals)).begin(); _iter959 != (*(this->part_vals)).end(); ++_iter959)
     {
-      xfer += oprot->writeString((*_iter963));
+      xfer += oprot->writeString((*_iter959));
     }
     xfer += oprot->writeListEnd();
   }
@@ -12178,17 +12178,17 @@ uint32_t ThriftHiveMetastore_exchange_partition_args::read(::apache::thrift::pro
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->partitionSpecs.clear();
-            uint32_t _size964;
-            ::apache::thrift::protocol::TType _ktype965;
-            ::apache::thrift::protocol::TType _vtype966;
-            xfer += iprot->readMapBegin(_ktype965, _vtype966, _size964);
-            uint32_t _i968;
-            for (_i968 = 0; _i968 < _size964; ++_i968)
+            uint32_t _size960;
+            ::apache::thrift::protocol::TType _ktype961;
+            ::apache::thrift::protocol::TType _vtype962;
+            xfer += iprot->readMapBegin(_ktype961, _vtype962, _size960);
+            uint32_t _i964;
+            for (_i964 = 0; _i964 < _size960; ++_i964)
             {
-              std::string _key969;
-              xfer += iprot->readString(_key969);
-              std::string& _val970 = this->partitionSpecs[_key969];
-              xfer += iprot->readString(_val970);
+              std::string _key965;
+              xfer += iprot->readString(_key965);
+              std::string& _val966 = this->partitionSpecs[_key965];
+              xfer += iprot->readString(_val966);
             }
             xfer += iprot->readMapEnd();
           }
@@ -12249,11 +12249,11 @@ uint32_t ThriftHiveMetastore_exchange_partition_args::write(::apache::thrift::pr
   xfer += oprot->writeFieldBegin("partitionSpecs", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->partitionSpecs.size()));
-    std::map<std::string, std::string> ::const_iterator _iter971;
-    for (_iter971 = this->partitionSpecs.begin(); _iter971 != this->partitionSpecs.end(); ++_iter971)
+    std::map<std::string, std::string> ::const_iterator _iter967;
+    for (_iter967 = this->partitionSpecs.begin(); _iter967 != this->partitionSpecs.end(); ++_iter967)
     {
-      xfer += oprot->writeString(_iter971->first);
-      xfer += oprot->writeString(_iter971->second);
+      xfer += oprot->writeString(_iter967->first);
+      xfer += oprot->writeString(_iter967->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -12293,11 +12293,11 @@ uint32_t ThriftHiveMetastore_exchange_partition_pargs::write(::apache::thrift::p
   xfer += oprot->writeFieldBegin("partitionSpecs", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->partitionSpecs)).size()));
-    std::map<std::string, std::string> ::const_iterator _iter972;
-    for (_iter972 = (*(this->partitionSpecs)).begin(); _iter972 != (*(this->partitionSpecs)).end(); ++_iter972)
+    std::map<std::string, std::string> ::const_iterator _iter968;
+    for (_iter968 = (*(this->partitionSpecs)).begin(); _iter968 != (*(this->partitionSpecs)).end(); ++_iter968)
     {
-      xfer += oprot->writeString(_iter972->first);
-      xfer += oprot->writeString(_iter972->second);
+      xfer += oprot->writeString(_iter968->first);
+      xfer += oprot->writeString(_iter968->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -12542,17 +12542,17 @@ uint32_t ThriftHiveMetastore_exchange_partitions_args::read(::apache::thrift::pr
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->partitionSpecs.clear();
-            uint32_t _size973;
-            ::apache::thrift::protocol::TType _ktype974;
-            ::apache::thrift::protocol::TType _vtype975;
-            xfer += iprot->readMapBegin(_ktype974, _vtype975, _size973);
-            uint32_t _i977;
-            for (_i977 = 0; _i977 < _size973; ++_i977)
+            uint32_t _size969;
+            ::apache::thrift::protocol::TType _ktype970;
+            ::apache::thrift::protocol::TType _vtype971;
+            xfer += iprot->readMapBegin(_ktype970, _vtype971, _size969);
+            uint32_t _i973;
+            for (_i973 = 0; _i973 < _size969; ++_i973)
             {
-              std::string _key978;
-              xfer += iprot->readString(_key978);
-              std::string& _val979 = this->partitionSpecs[_key978];
-              xfer += iprot->readString(_val979);
+              std::string _key974;
+              xfer += iprot->readString(_key974);
+              std::string& _val975 = this->partitionSpecs[_key974];
+              xfer += iprot->readString(_val975);
             }
             xfer += iprot->readMapEnd();
           }
@@ -12613,11 +12613,11 @@ uint32_t ThriftHiveMetastore_exchange_partitions_args::write(::apache::thrift::p
   xfer += oprot->writeFieldBegin("partitionSpecs", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->partitionSpecs.size()));
-    std::map<std::string, std::string> ::const_iterator _iter980;
-    for (_iter980 = this->partitionSpecs.begin(); _iter980 != this->partitionSpecs.end(); ++_iter980)
+    std::map<std::string, std::string> ::const_iterator _iter976;
+    for (_iter976 = this->partitionSpecs.begin(); _iter976 != this->partitionSpecs.end(); ++_iter976)
     {
-      xfer += oprot->writeString(_iter980->first);
-      xfer += oprot->writeString(_iter980->second);
+      xfer += oprot->writeString(_iter976->first);
+      xfer += oprot->writeString(_iter976->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -12657,11 +12657,11 @@ uint32_t ThriftHiveMetastore_exchange_partitions_pargs::write(::apache::thrift::
   xfer += oprot->writeFieldBegin("partitionSpecs", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->partitionSpecs)).size()));
-    std::map<std::string, std::string> ::const_iterator _iter981;
-    for (_iter981 = (*(this->partitionSpecs)).begin(); _iter981 != (*(this->partitionSpecs)).end(); ++_iter981)
+    std::map<std::string, std::string> ::const_iterator _iter977;
+    for (_iter977 = (*(this->partitionSpecs)).begin(); _iter977 != (*(this->partitionSpecs)).end(); ++_iter977)
     {
-      xfer += oprot->writeString(_iter981->first);
-      xfer += oprot->writeString(_iter981->second);
+      xfer += oprot->writeString(_iter977->first);
+      xfer += oprot->writeString(_iter977->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -12718,14 +12718,14 @@ uint32_t ThriftHiveMetastore_exchange_partitions_result::read(::apache::thrift::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size982;
-            ::apache::thrift::protocol::TType _etype985;
-            xfer += iprot->readListBegin(_etype985, _size982);
-            this->success.resize(_size982);
-            uint32_t _i986;
-            for (_i986 = 0; _i986 < _size982; ++_i986)
+            uint32_t _size978;
+            ::apache::thrift::protocol::TType _etype981;
+            xfer += iprot->readListBegin(_etype981, _size978);
+            this->success.resize(_size978);
+            uint32_t _i982;
+            for (_i982 = 0; _i982 < _size978; ++_i982)
             {
-              xfer += this->success[_i986].read(iprot);
+              xfer += this->success[_i982].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -12788,10 +12788,10 @@ uint32_t ThriftHiveMetastore_exchange_partitions_result::write(::apache::thrift:
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<Partition> ::const_iterator _iter987;
-      for (_iter987 = this->success.begin(); _iter987 != this->success.end(); ++_iter987)
+      std::vector<Partition> ::const_iterator _iter983;
+      for (_iter983 = this->success.begin(); _iter983 != this->success.end(); ++_iter983)
       {
-        xfer += (*_iter987).write(oprot);
+        xfer += (*_iter983).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -12848,14 +12848,14 @@ uint32_t ThriftHiveMetastore_exchange_partitions_presult::read(::apache::thrift:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size988;
-            ::apache::thrift::protocol::TType _etype991;
-            xfer += iprot->readListBegin(_etype991, _size988);
-            (*(this->success)).resize(_size988);
-            uint32_t _i992;
-            for (_i992 = 0; _i992 < _size988; ++_i992)
+            uint32_t _size984;
+            ::apache::thrift::protocol::TType _etype987;
+            xfer += iprot->readListBegin(_etype987, _size984);
+            (*(this->success)).resize(_size984);
+            uint32_t _i988;
+            for (_i988 = 0; _i988 < _size984; ++_i988)
             {
-              xfer += (*(this->success))[_i992].read(iprot);
+              xfer += (*(this->success))[_i988].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -12954,14 +12954,14 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_args::read(::apache::thrift
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->part_vals.clear();
-            uint32_t _size993;
-            ::apache::thrift::protocol::TType _etype996;
-            xfer += iprot->readListBegin(_etype996, _size993);
-            this->part_vals.resize(_size993);
-            uint32_t _i997;
-            for (_i997 = 0; _i997 < _size993; ++_i997)
+            uint32_t _size989;
+            ::apache::thrift::protocol::TType _etype992;
+            xfer += iprot->readListBegin(_etype992, _size989);
+            this->part_vals.resize(_size989);
+            uint32_t _i993;
+            for (_i993 = 0; _i993 < _size989; ++_i993)
             {
-              xfer += iprot->readString(this->part_vals[_i997]);
+              xfer += iprot->readString(this->part_vals[_i993]);
             }
             xfer += iprot->readListEnd();
           }
@@ -12982,14 +12982,14 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_args::read(::apache::thrift
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->group_names.clear();
-            uint32_t _size998;
-            ::apache::thrift::protocol::TType _etype1001;
-            xfer += iprot->readListBegin(_etype1001, _size998);
-            this->group_names.resize(_size998);
-            uint32_t _i1002;
-            for (_i1002 = 0; _i1002 < _size998; ++_i1002)
+            uint32_t _size994;
+            ::apache::thrift::protocol::TType _etype997;
+            xfer += iprot->readListBegin(_etype997, _size994);
+            this->group_names.resize(_size994);
+            uint32_t _i998;
+            for (_i998 = 0; _i998 < _size994; ++_i998)
             {
-              xfer += iprot->readString(this->group_names[_i1002]);
+              xfer += iprot->readString(this->group_names[_i998]);
             }
             xfer += iprot->readListEnd();
           }
@@ -13026,10 +13026,10 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_args::write(::apache::thrif
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->part_vals.size()));
-    std::vector<std::string> ::const_iterator _iter1003;
-    for (_iter1003 = this->part_vals.begin(); _iter1003 != this->part_vals.end(); ++_iter1003)
+    std::vector<std::string> ::const_iterator _iter999;
+    for (_iter999 = this->part_vals.begin(); _iter999 != this->part_vals.end(); ++_iter999)
     {
-      xfer += oprot->writeString((*_iter1003));
+      xfer += oprot->writeString((*_iter999));
     }
     xfer += oprot->writeListEnd();
   }
@@ -13042,10 +13042,10 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_args::write(::apache::thrif
   xfer += oprot->writeFieldBegin("group_names", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->group_names.size()));
-    std::vector<std::string> ::const_iterator _iter1004;
-    for (_iter1004 = this->group_names.begin(); _iter1004 != this->group_names.end(); ++_iter1004)
+    std::vector<std::string> ::const_iterator _iter1000;
+    for (_iter1000 = this->group_names.begin(); _iter1000 != this->group_names.end(); ++_iter1000)
     {
-      xfer += oprot->writeString((*_iter1004));
+      xfer += oprot->writeString((*_iter1000));
     }
     xfer += oprot->writeListEnd();
   }
@@ -13077,10 +13077,10 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_pargs::write(::apache::thri
   xfer += oprot->writeFieldBegin("part_vals", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->part_vals)).size()));
-    std::vector<std::string> ::const_iterator _iter1005;
-    for (_iter1005 = (*(this->part_vals)).begin(); _iter1005 != (*(this->part_vals)).end(); ++_iter1005)
+    std::vector<std::string> ::const_iterator _iter1001;
+    for (_iter1001 = (*(this->part_vals)).begin(); _iter1001 != (*(this->part_vals)).end(); ++_iter1001)
     {
-      xfer += oprot->writeString((*_iter1005));
+      xfer += oprot->writeString((*_iter1001));
     }
     xfer += oprot->writeListEnd();
   }
@@ -13093,10 +13093,10 @@ uint32_t ThriftHiveMetastore_get_partition_with_auth_pargs::write(::apache::thri
   xfer += oprot->writeFieldBegin("group_names", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->group_names)).size()));
-    std::vector<std::string> ::const_iterator _iter1006;
-    for (_iter1006 = (*(this->group_names)).begin(); _iter1006 != (*(this->group_names)).end(); ++_iter1006)
+    std::vector<std::string> ::const_iterator _iter1002;
+    for (_iter1002 = (*(this->group_names)).begin(); _iter1002 != (*(this->group_names)).end(); ++_iter1002)
     {
-      xfer += oprot->writeString((*_iter1006));
+      xfer += oprot->writeString((*_iter1002));
     }
     xfer += oprot->writeListEnd();
   }
@@ -13655,14 +13655,14 @@ uint32_t ThriftHiveMetastore_get_partitions_result::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size1007;
-            ::apache::thrift::protocol::TType _etype1010;
-            xfer += iprot->readListBegin(_etype1010, _size1007);
-            this->success.resize(_size1007);
-            uint32_t _i1011;
-            for (_i1011 = 0; _i1011 < _size1007; ++_i1011)
+            uint32_t _size1003;
+            ::apache::thrift::protocol::TType _etype1006;
+            xfer += iprot->readListBegin(_etype1006, _size1003);
+            this->success.resize(_size1003);
+            uint32_t _i1007;
+            for (_i1007 = 0; _i1007 < _size1003; ++_i1007)
             {
-              xfer += this->success[_i1011].read(iprot);
+              xfer += this->success[_i1007].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -13709,10 +13709,10 @@ uint32_t ThriftHiveMetastore_get_partitions_result::write(::apache::thrift::prot
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<Partition> ::const_iterator _iter1012;
-      for (_iter1012 = this->success.begin(); _iter1012 != this->success.end(); ++_iter1012)
+      std::vector<Partition> ::const_iterator _iter1008;
+      for (_iter1008 = this->success.begin(); _iter1008 != this->success.end(); ++_iter1008)
       {
-        xfer += (*_iter1012).write(oprot);
+        xfer += (*_iter1008).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -13761,14 +13761,14 @@ uint32_t ThriftHiveMetastore_get_partitions_presult::read(::apache::thrift::prot
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size1013;
-            ::apache::thrift::protocol::TType _etype1016;
-            xfer += iprot->readListBegin(_etype1016, _size1013);
-            (*(this->success)).resize(_size1013);
-            uint32_t _i1017;
-            for (_i1017 = 0; _i1017 < _size1013; ++_i1017)
+            uint32_t _size1009;
+            ::apache::thrift::protocol::TType _etype1012;
+            xfer += iprot->readListBegin(_etype1012, _size1009);
+            (*(this->success)).resize(_size1009);
+            uint32_t _i1013;
+            for (_i1013 = 0; _i1013 < _size1009; ++_i1013)
             {
-              xfer += (*(this->success))[_i1017].read(iprot);
+              xfer += (*(this->success))[_i1013].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -13867,14 +13867,14 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_args::read(::apache::thrif
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->group_names.clear();
-            uint32_t _size1018;
-            ::apache::thrift::protocol::TType _etype1021;
-            xfer += iprot->readListBegin(_etype1021, _size1018);
-            this->group_names.resize(_size1018);
-            uint32_t _i1022;
-            for (_i1022 = 0; _i1022 < _size1018; ++_i1022)
+            uint32_t _size1014;
+            ::apache::thrift::protocol::TType _etype1017;
+            xfer += iprot->readListBegin(_etype1017, _size1014);
+            this->group_names.resize(_size1014);
+            uint32_t _i1018;
+            for (_i1018 = 0; _i1018 < _size1014; ++_i1018)
             {
-              xfer += iprot->readString(this->group_names[_i1022]);
+              xfer += iprot->readString(this->group_names[_i1018]);
             }
             xfer += iprot->readListEnd();
           }
@@ -13919,10 +13919,10 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_args::write(::apache::thri
   xfer += oprot->writeFieldBegin("group_names", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->group_names.size()));
-    std::vector<std::string> ::const_iterator _iter1023;
-    for (_iter1023 = this->group_names.begin(); _iter1023 != this->group_names.end(); ++_iter1023)
+    std::vector<std::string> ::const_iterator _iter1019;
+    for (_iter1019 = this->group_names.begin(); _iter1019 != this->group_names.end(); ++_iter1019)
     {
-      xfer += oprot->writeString((*_iter1023));
+      xfer += oprot->writeString((*_iter1019));
     }
     xfer += oprot->writeListEnd();
   }
@@ -13962,10 +13962,10 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_pargs::write(::apache::thr
   xfer += oprot->writeFieldBegin("group_names", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->group_names)).size()));
-    std::vector<std::string> ::const_iterator _iter1024;
-    for (_iter1024 = (*(this->group_names)).begin(); _iter1024 != (*(this->group_names)).end(); ++_iter1024)
+    std::vector<std::string> ::const_iterator _iter1020;
+    for (_iter1020 = (*(this->group_names)).begin(); _iter1020 != (*(this->group_names)).end(); ++_iter1020)
     {
-      xfer += oprot->writeString((*_iter1024));
+      xfer += oprot->writeString((*_iter1020));
     }
     xfer += oprot->writeListEnd();
   }
@@ -14006,14 +14006,14 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_result::read(::apache::thr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size1025;
-            ::apache::thrift::protocol::TType _etype1028;
-            xfer += iprot->readListBegin(_etype1028, _size1025);
-            this->success.resize(_size1025);
-            uint32_t _i1029;
-            for (_i1029 = 0; _i1029 < _size1025; ++_i1029)
+            uint32_t _size1021;
+            ::apache::thrift::protocol::TType _etype1024;
+            xfer += iprot->readListBegin(_etype1024, _size1021);
+            this->success.resize(_size1021);
+            uint32_t _i1025;
+            for (_i1025 = 0; _i1025 < _size1021; ++_i1025)
             {
-              xfer += this->success[_i1029].read(iprot);
+              xfer += this->success[_i1025].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -14060,10 +14060,10 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_result::write(::apache::th
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<Partition> ::const_iterator _iter1030;
-      for (_iter1030 = this->success.begin(); _iter1030 != this->success.end(); ++_iter1030)
+      std::vector<Partition> ::const_iterator _iter1026;
+      for (_iter1026 = this->success.begin(); _iter1026 != this->success.end(); ++_iter1026)
       {
-        xfer += (*_iter1030).write(oprot);
+        xfer += (*_iter1026).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -14112,14 +14112,14 @@ uint32_t ThriftHiveMetastore_get_partitions_with_auth_presult::read(::apache::th
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size1031;
-            ::apache::thrift::protocol::TType _etype1034;
-            xfer += iprot->readListBegin(_etype1034, _size1031);
-            (*(this->success)).resize(_size1031);
-            uint32_t _i1035;
-            for (_i1035 = 0; _i1035 < _size1031; ++_i1035)
+            uint32_t _size1027;
+            ::apache::thrift::protocol::TType _etype1030;
+            xfer += iprot->readListBegin(_etype1030, _size1027);
+            (*(this->success)).resize(_size1027);
+            uint32_t _i1031;
+            for (_i1031 = 0; _i1031 < _size1027; ++_i1031)
             {
-              xfer += (*(this->success))[_i1035].read(iprot);
+              xfer += (*(this->success))[_i1031].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -14297,14 +14297,14 @@ uint32_t ThriftHiveMetastore_get_partitions_pspec_result::read(::apache::thrift:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size1036;
-            ::apache::thrift::protocol::TType _etype1039;
-            xfer += iprot->readListBegin(_etype1039, _size1036);
-            this->success.resize(_size1036);
-            uint32_t _i1040;
-            for (_i1040 = 0; _i1040 < _size1036; ++_i1040)
+            uint32_t _size1032;
+            ::apache::thrift::protocol::TType _etype1035;
+            xfer += iprot->readListBegin(_etype1035, _size1032);
+            this->success.resize(_size1032);
+            uint32_t _i1036;
+            for (_i1036 = 0; _i1036 < _size1032; ++_i1036)
             {
-              xfer += this->success[_i1040].read(iprot);
+              xfer += this->success[_i1036].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -14351,10 +14351,10 @@ uint32_t ThriftHiveMetastore_get_partitions_pspec_result::write(::apache::thrift
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<PartitionSpec> ::const_iterator _iter1041;
-      for (_iter1041 = this->success.begin(); _iter1041 != this->success.end(); ++_iter1041)
+      std::vector<PartitionSpec> ::const_iterator _iter1037;
+      for (_iter1037 = this->success.begin(); _iter1037 != this->success.end(); ++_iter1037)
       {
-        xfer += (*_iter1041).write(oprot);
+        xfer += (*_iter1037).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -14403,14 +14403,14 @@ uint32_t ThriftHiveMetastore_get_partitions_pspec_presult::read(::apache::thrift
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size1042;
-            ::apache::thrift::protocol::TType _etype1045;
-            xfer += iprot->readListBegin(_etype1045, _size1042);
-            (*(this->success)).resize(_size1042);
-            uint32_t _i1046;
-            for (_i1046 = 0; _i1046 < _size1042; ++_i1046)
+            uint32_t _size1038;
+            ::apache::thrift::protocol::TType _etype1041;
+            xfer += iprot->readListBegin(_etype1041, _size1038);
+            (*(this->success)).resize(_size1038);
+            uint32_t _i1042;
+            for (_i1042 = 0; _i1042 < _size1038; ++_i1042)
             {
-              xfer += (*(this->success))[_i1046].read(iprot);
+              xfer += (*(this->success))[_i1042].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -14588,14 +14588,14 @@ uint32_t ThriftHiveMetastore_get_partition_names_result::read(::apache::thrift::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size1047;
-            ::apache::thrift::protocol::TType _etype1050;
-            xfer += iprot->readListBegin(_etype1050, _size1047);
-            this->success.resize(_size1047);
-            uint32_t _i1051;
-            for (_i1051 = 0; _i1051 < _size1047; ++_i1051)
+            uint32_t _size1043;
+            ::apache::thrift::protocol::TType _etype1046;
+            xfer += iprot->readListBegin(_etype1046, _size1043);
+            this->success.resize(_size1043);
+            uint32_t _i1047;
+            for (_i1047 = 0; _i1047 < _size1043; ++_i1047)
             {
-              xfer += iprot->readString(this->success[_i1051]);
+              xfer += iprot->readString(this->success[_i1047]);
             }
             xfer += iprot->readListEnd();
           }
@@ -14634,10 +14634,10 @@ uint32_t ThriftHiveMetastore_get_partition_names

<TRUNCATED>

[2/5] hive git commit: HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)

Posted by se...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
index 2a81c4b..f4700a1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
@@ -334,8 +334,6 @@ public class ThriftHiveMetastore {
 
     public CacheFileMetadataResult cache_file_metadata(CacheFileMetadataRequest req) throws org.apache.thrift.TException;
 
-    public GetChangeVersionResult get_change_version(GetChangeVersionRequest req) throws org.apache.thrift.TException;
-
   }
 
   public interface AsyncIface extends com.facebook.fb303.FacebookService .AsyncIface {
@@ -632,8 +630,6 @@ public class ThriftHiveMetastore {
 
     public void cache_file_metadata(CacheFileMetadataRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_change_version(GetChangeVersionRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
-
   }
 
   public static class Client extends com.facebook.fb303.FacebookService.Client implements Iface {
@@ -4880,29 +4876,6 @@ public class ThriftHiveMetastore {
       throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "cache_file_metadata failed: unknown result");
     }
 
-    public GetChangeVersionResult get_change_version(GetChangeVersionRequest req) throws org.apache.thrift.TException
-    {
-      send_get_change_version(req);
-      return recv_get_change_version();
-    }
-
-    public void send_get_change_version(GetChangeVersionRequest req) throws org.apache.thrift.TException
-    {
-      get_change_version_args args = new get_change_version_args();
-      args.setReq(req);
-      sendBase("get_change_version", args);
-    }
-
-    public GetChangeVersionResult recv_get_change_version() throws org.apache.thrift.TException
-    {
-      get_change_version_result result = new get_change_version_result();
-      receiveBase(result, "get_change_version");
-      if (result.isSetSuccess()) {
-        return result.success;
-      }
-      throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_change_version failed: unknown result");
-    }
-
   }
   public static class AsyncClient extends com.facebook.fb303.FacebookService.AsyncClient implements AsyncIface {
     public static class Factory implements org.apache.thrift.async.TAsyncClientFactory<AsyncClient> {
@@ -10076,38 +10049,6 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_change_version(GetChangeVersionRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
-      checkReady();
-      get_change_version_call method_call = new get_change_version_call(req, resultHandler, this, ___protocolFactory, ___transport);
-      this.___currentMethod = method_call;
-      ___manager.call(method_call);
-    }
-
-    public static class get_change_version_call extends org.apache.thrift.async.TAsyncMethodCall {
-      private GetChangeVersionRequest req;
-      public get_change_version_call(GetChangeVersionRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
-        super(client, protocolFactory, transport, resultHandler, false);
-        this.req = req;
-      }
-
-      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
-        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("get_change_version", org.apache.thrift.protocol.TMessageType.CALL, 0));
-        get_change_version_args args = new get_change_version_args();
-        args.setReq(req);
-        args.write(prot);
-        prot.writeMessageEnd();
-      }
-
-      public GetChangeVersionResult getResult() throws org.apache.thrift.TException {
-        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
-          throw new IllegalStateException("Method call not finished!");
-        }
-        org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array());
-        org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport);
-        return (new Client(prot)).recv_get_change_version();
-      }
-    }
-
   }
 
   public static class Processor<I extends Iface> extends com.facebook.fb303.FacebookService.Processor<I> implements org.apache.thrift.TProcessor {
@@ -10267,7 +10208,6 @@ public class ThriftHiveMetastore {
       processMap.put("put_file_metadata", new put_file_metadata());
       processMap.put("clear_file_metadata", new clear_file_metadata());
       processMap.put("cache_file_metadata", new cache_file_metadata());
-      processMap.put("get_change_version", new get_change_version());
       return processMap;
     }
 
@@ -14001,26 +13941,6 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public static class get_change_version<I extends Iface> extends org.apache.thrift.ProcessFunction<I, get_change_version_args> {
-      public get_change_version() {
-        super("get_change_version");
-      }
-
-      public get_change_version_args getEmptyArgsInstance() {
-        return new get_change_version_args();
-      }
-
-      protected boolean isOneway() {
-        return false;
-      }
-
-      public get_change_version_result getResult(I iface, get_change_version_args args) throws org.apache.thrift.TException {
-        get_change_version_result result = new get_change_version_result();
-        result.success = iface.get_change_version(args.req);
-        return result;
-      }
-    }
-
   }
 
   public static class AsyncProcessor<I extends AsyncIface> extends com.facebook.fb303.FacebookService.AsyncProcessor<I> {
@@ -14180,7 +14100,6 @@ public class ThriftHiveMetastore {
       processMap.put("put_file_metadata", new put_file_metadata());
       processMap.put("clear_file_metadata", new clear_file_metadata());
       processMap.put("cache_file_metadata", new cache_file_metadata());
-      processMap.put("get_change_version", new get_change_version());
       return processMap;
     }
 
@@ -23085,57 +23004,6 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public static class get_change_version<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, get_change_version_args, GetChangeVersionResult> {
-      public get_change_version() {
-        super("get_change_version");
-      }
-
-      public get_change_version_args getEmptyArgsInstance() {
-        return new get_change_version_args();
-      }
-
-      public AsyncMethodCallback<GetChangeVersionResult> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
-        final org.apache.thrift.AsyncProcessFunction fcall = this;
-        return new AsyncMethodCallback<GetChangeVersionResult>() { 
-          public void onComplete(GetChangeVersionResult o) {
-            get_change_version_result result = new get_change_version_result();
-            result.success = o;
-            try {
-              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
-              return;
-            } catch (Exception e) {
-              LOGGER.error("Exception writing to internal frame buffer", e);
-            }
-            fb.close();
-          }
-          public void onError(Exception e) {
-            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
-            org.apache.thrift.TBase msg;
-            get_change_version_result result = new get_change_version_result();
-            {
-              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
-              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
-            }
-            try {
-              fcall.sendResponse(fb,msg,msgType,seqid);
-              return;
-            } catch (Exception ex) {
-              LOGGER.error("Exception writing to internal frame buffer", ex);
-            }
-            fb.close();
-          }
-        };
-      }
-
-      protected boolean isOneway() {
-        return false;
-      }
-
-      public void start(I iface, get_change_version_args args, org.apache.thrift.async.AsyncMethodCallback<GetChangeVersionResult> resultHandler) throws TException {
-        iface.get_change_version(args.req,resultHandler);
-      }
-    }
-
   }
 
   public static class getMetaConf_args implements org.apache.thrift.TBase<getMetaConf_args, getMetaConf_args._Fields>, java.io.Serializable, Cloneable, Comparable<getMetaConf_args>   {
@@ -169383,695 +169251,33 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(flushCache_result.class, metaDataMap);
-    }
-
-    public flushCache_result() {
-    }
-
-    /**
-     * Performs a deep copy on <i>other</i>.
-     */
-    public flushCache_result(flushCache_result other) {
-    }
-
-    public flushCache_result deepCopy() {
-      return new flushCache_result(this);
-    }
-
-    @Override
-    public void clear() {
-    }
-
-    public void setFieldValue(_Fields field, Object value) {
-      switch (field) {
-      }
-    }
-
-    public Object getFieldValue(_Fields field) {
-      switch (field) {
-      }
-      throw new IllegalStateException();
-    }
-
-    /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
-    public boolean isSet(_Fields field) {
-      if (field == null) {
-        throw new IllegalArgumentException();
-      }
-
-      switch (field) {
-      }
-      throw new IllegalStateException();
-    }
-
-    @Override
-    public boolean equals(Object that) {
-      if (that == null)
-        return false;
-      if (that instanceof flushCache_result)
-        return this.equals((flushCache_result)that);
-      return false;
-    }
-
-    public boolean equals(flushCache_result that) {
-      if (that == null)
-        return false;
-
-      return true;
-    }
-
-    @Override
-    public int hashCode() {
-      List<Object> list = new ArrayList<Object>();
-
-      return list.hashCode();
-    }
-
-    @Override
-    public int compareTo(flushCache_result other) {
-      if (!getClass().equals(other.getClass())) {
-        return getClass().getName().compareTo(other.getClass().getName());
-      }
-
-      int lastComparison = 0;
-
-      return 0;
-    }
-
-    public _Fields fieldForId(int fieldId) {
-      return _Fields.findByThriftId(fieldId);
-    }
-
-    public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
-      schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
-    }
-
-    public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
-      schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
-      }
-
-    @Override
-    public String toString() {
-      StringBuilder sb = new StringBuilder("flushCache_result(");
-      boolean first = true;
-
-      sb.append(")");
-      return sb.toString();
-    }
-
-    public void validate() throws org.apache.thrift.TException {
-      // check for required fields
-      // check for sub-struct validity
-    }
-
-    private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
-      try {
-        write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
-      } catch (org.apache.thrift.TException te) {
-        throw new java.io.IOException(te);
-      }
-    }
-
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
-      try {
-        read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
-      } catch (org.apache.thrift.TException te) {
-        throw new java.io.IOException(te);
-      }
-    }
-
-    private static class flushCache_resultStandardSchemeFactory implements SchemeFactory {
-      public flushCache_resultStandardScheme getScheme() {
-        return new flushCache_resultStandardScheme();
-      }
-    }
-
-    private static class flushCache_resultStandardScheme extends StandardScheme<flushCache_result> {
-
-      public void read(org.apache.thrift.protocol.TProtocol iprot, flushCache_result struct) throws org.apache.thrift.TException {
-        org.apache.thrift.protocol.TField schemeField;
-        iprot.readStructBegin();
-        while (true)
-        {
-          schemeField = iprot.readFieldBegin();
-          if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
-            break;
-          }
-          switch (schemeField.id) {
-            default:
-              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-          }
-          iprot.readFieldEnd();
-        }
-        iprot.readStructEnd();
-        struct.validate();
-      }
-
-      public void write(org.apache.thrift.protocol.TProtocol oprot, flushCache_result struct) throws org.apache.thrift.TException {
-        struct.validate();
-
-        oprot.writeStructBegin(STRUCT_DESC);
-        oprot.writeFieldStop();
-        oprot.writeStructEnd();
-      }
-
-    }
-
-    private static class flushCache_resultTupleSchemeFactory implements SchemeFactory {
-      public flushCache_resultTupleScheme getScheme() {
-        return new flushCache_resultTupleScheme();
-      }
-    }
-
-    private static class flushCache_resultTupleScheme extends TupleScheme<flushCache_result> {
-
-      @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, flushCache_result struct) throws org.apache.thrift.TException {
-        TTupleProtocol oprot = (TTupleProtocol) prot;
-      }
-
-      @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, flushCache_result struct) throws org.apache.thrift.TException {
-        TTupleProtocol iprot = (TTupleProtocol) prot;
-      }
-    }
-
-  }
-
-  public static class get_file_metadata_by_expr_args implements org.apache.thrift.TBase<get_file_metadata_by_expr_args, get_file_metadata_by_expr_args._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_by_expr_args>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_by_expr_args");
-
-    private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
-
-    private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
-    static {
-      schemes.put(StandardScheme.class, new get_file_metadata_by_expr_argsStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new get_file_metadata_by_expr_argsTupleSchemeFactory());
-    }
-
-    private GetFileMetadataByExprRequest req; // required
-
-    /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
-      REQ((short)1, "req");
-
-      private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
-
-      static {
-        for (_Fields field : EnumSet.allOf(_Fields.class)) {
-          byName.put(field.getFieldName(), field);
-        }
-      }
-
-      /**
-       * Find the _Fields constant that matches fieldId, or null if its not found.
-       */
-      public static _Fields findByThriftId(int fieldId) {
-        switch(fieldId) {
-          case 1: // REQ
-            return REQ;
-          default:
-            return null;
-        }
-      }
-
-      /**
-       * Find the _Fields constant that matches fieldId, throwing an exception
-       * if it is not found.
-       */
-      public static _Fields findByThriftIdOrThrow(int fieldId) {
-        _Fields fields = findByThriftId(fieldId);
-        if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
-        return fields;
-      }
-
-      /**
-       * Find the _Fields constant that matches name, or null if its not found.
-       */
-      public static _Fields findByName(String name) {
-        return byName.get(name);
-      }
-
-      private final short _thriftId;
-      private final String _fieldName;
-
-      _Fields(short thriftId, String fieldName) {
-        _thriftId = thriftId;
-        _fieldName = fieldName;
-      }
-
-      public short getThriftFieldId() {
-        return _thriftId;
-      }
-
-      public String getFieldName() {
-        return _fieldName;
-      }
-    }
-
-    // isset id assignments
-    public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
-    static {
-      Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
-      tmpMap.put(_Fields.REQ, new org.apache.thrift.meta_data.FieldMetaData("req", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataByExprRequest.class)));
-      metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_by_expr_args.class, metaDataMap);
-    }
-
-    public get_file_metadata_by_expr_args() {
-    }
-
-    public get_file_metadata_by_expr_args(
-      GetFileMetadataByExprRequest req)
-    {
-      this();
-      this.req = req;
-    }
-
-    /**
-     * Performs a deep copy on <i>other</i>.
-     */
-    public get_file_metadata_by_expr_args(get_file_metadata_by_expr_args other) {
-      if (other.isSetReq()) {
-        this.req = new GetFileMetadataByExprRequest(other.req);
-      }
-    }
-
-    public get_file_metadata_by_expr_args deepCopy() {
-      return new get_file_metadata_by_expr_args(this);
-    }
-
-    @Override
-    public void clear() {
-      this.req = null;
-    }
-
-    public GetFileMetadataByExprRequest getReq() {
-      return this.req;
-    }
-
-    public void setReq(GetFileMetadataByExprRequest req) {
-      this.req = req;
-    }
-
-    public void unsetReq() {
-      this.req = null;
-    }
-
-    /** Returns true if field req is set (has been assigned a value) and false otherwise */
-    public boolean isSetReq() {
-      return this.req != null;
-    }
-
-    public void setReqIsSet(boolean value) {
-      if (!value) {
-        this.req = null;
-      }
-    }
-
-    public void setFieldValue(_Fields field, Object value) {
-      switch (field) {
-      case REQ:
-        if (value == null) {
-          unsetReq();
-        } else {
-          setReq((GetFileMetadataByExprRequest)value);
-        }
-        break;
-
-      }
-    }
-
-    public Object getFieldValue(_Fields field) {
-      switch (field) {
-      case REQ:
-        return getReq();
-
-      }
-      throw new IllegalStateException();
-    }
-
-    /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
-    public boolean isSet(_Fields field) {
-      if (field == null) {
-        throw new IllegalArgumentException();
-      }
-
-      switch (field) {
-      case REQ:
-        return isSetReq();
-      }
-      throw new IllegalStateException();
-    }
-
-    @Override
-    public boolean equals(Object that) {
-      if (that == null)
-        return false;
-      if (that instanceof get_file_metadata_by_expr_args)
-        return this.equals((get_file_metadata_by_expr_args)that);
-      return false;
-    }
-
-    public boolean equals(get_file_metadata_by_expr_args that) {
-      if (that == null)
-        return false;
-
-      boolean this_present_req = true && this.isSetReq();
-      boolean that_present_req = true && that.isSetReq();
-      if (this_present_req || that_present_req) {
-        if (!(this_present_req && that_present_req))
-          return false;
-        if (!this.req.equals(that.req))
-          return false;
-      }
-
-      return true;
-    }
-
-    @Override
-    public int hashCode() {
-      List<Object> list = new ArrayList<Object>();
-
-      boolean present_req = true && (isSetReq());
-      list.add(present_req);
-      if (present_req)
-        list.add(req);
-
-      return list.hashCode();
-    }
-
-    @Override
-    public int compareTo(get_file_metadata_by_expr_args other) {
-      if (!getClass().equals(other.getClass())) {
-        return getClass().getName().compareTo(other.getClass().getName());
-      }
-
-      int lastComparison = 0;
-
-      lastComparison = Boolean.valueOf(isSetReq()).compareTo(other.isSetReq());
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-      if (isSetReq()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.req, other.req);
-        if (lastComparison != 0) {
-          return lastComparison;
-        }
-      }
-      return 0;
-    }
-
-    public _Fields fieldForId(int fieldId) {
-      return _Fields.findByThriftId(fieldId);
-    }
-
-    public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
-      schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
-    }
-
-    public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
-      schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
-    }
-
-    @Override
-    public String toString() {
-      StringBuilder sb = new StringBuilder("get_file_metadata_by_expr_args(");
-      boolean first = true;
-
-      sb.append("req:");
-      if (this.req == null) {
-        sb.append("null");
-      } else {
-        sb.append(this.req);
-      }
-      first = false;
-      sb.append(")");
-      return sb.toString();
-    }
-
-    public void validate() throws org.apache.thrift.TException {
-      // check for required fields
-      // check for sub-struct validity
-      if (req != null) {
-        req.validate();
-      }
-    }
-
-    private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
-      try {
-        write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
-      } catch (org.apache.thrift.TException te) {
-        throw new java.io.IOException(te);
-      }
-    }
-
-    private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
-      try {
-        read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
-      } catch (org.apache.thrift.TException te) {
-        throw new java.io.IOException(te);
-      }
-    }
-
-    private static class get_file_metadata_by_expr_argsStandardSchemeFactory implements SchemeFactory {
-      public get_file_metadata_by_expr_argsStandardScheme getScheme() {
-        return new get_file_metadata_by_expr_argsStandardScheme();
-      }
-    }
-
-    private static class get_file_metadata_by_expr_argsStandardScheme extends StandardScheme<get_file_metadata_by_expr_args> {
-
-      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
-        org.apache.thrift.protocol.TField schemeField;
-        iprot.readStructBegin();
-        while (true)
-        {
-          schemeField = iprot.readFieldBegin();
-          if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
-            break;
-          }
-          switch (schemeField.id) {
-            case 1: // REQ
-              if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.req = new GetFileMetadataByExprRequest();
-                struct.req.read(iprot);
-                struct.setReqIsSet(true);
-              } else { 
-                org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-              }
-              break;
-            default:
-              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-          }
-          iprot.readFieldEnd();
-        }
-        iprot.readStructEnd();
-        struct.validate();
-      }
-
-      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
-        struct.validate();
-
-        oprot.writeStructBegin(STRUCT_DESC);
-        if (struct.req != null) {
-          oprot.writeFieldBegin(REQ_FIELD_DESC);
-          struct.req.write(oprot);
-          oprot.writeFieldEnd();
-        }
-        oprot.writeFieldStop();
-        oprot.writeStructEnd();
-      }
-
-    }
-
-    private static class get_file_metadata_by_expr_argsTupleSchemeFactory implements SchemeFactory {
-      public get_file_metadata_by_expr_argsTupleScheme getScheme() {
-        return new get_file_metadata_by_expr_argsTupleScheme();
-      }
-    }
-
-    private static class get_file_metadata_by_expr_argsTupleScheme extends TupleScheme<get_file_metadata_by_expr_args> {
-
-      @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
-        TTupleProtocol oprot = (TTupleProtocol) prot;
-        BitSet optionals = new BitSet();
-        if (struct.isSetReq()) {
-          optionals.set(0);
-        }
-        oprot.writeBitSet(optionals, 1);
-        if (struct.isSetReq()) {
-          struct.req.write(oprot);
-        }
-      }
-
-      @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
-        TTupleProtocol iprot = (TTupleProtocol) prot;
-        BitSet incoming = iprot.readBitSet(1);
-        if (incoming.get(0)) {
-          struct.req = new GetFileMetadataByExprRequest();
-          struct.req.read(iprot);
-          struct.setReqIsSet(true);
-        }
-      }
-    }
-
-  }
-
-  public static class get_file_metadata_by_expr_result implements org.apache.thrift.TBase<get_file_metadata_by_expr_result, get_file_metadata_by_expr_result._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_by_expr_result>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_by_expr_result");
-
-    private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
-
-    private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
-    static {
-      schemes.put(StandardScheme.class, new get_file_metadata_by_expr_resultStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new get_file_metadata_by_expr_resultTupleSchemeFactory());
-    }
-
-    private GetFileMetadataByExprResult success; // required
-
-    /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
-      SUCCESS((short)0, "success");
-
-      private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
-
-      static {
-        for (_Fields field : EnumSet.allOf(_Fields.class)) {
-          byName.put(field.getFieldName(), field);
-        }
-      }
-
-      /**
-       * Find the _Fields constant that matches fieldId, or null if its not found.
-       */
-      public static _Fields findByThriftId(int fieldId) {
-        switch(fieldId) {
-          case 0: // SUCCESS
-            return SUCCESS;
-          default:
-            return null;
-        }
-      }
-
-      /**
-       * Find the _Fields constant that matches fieldId, throwing an exception
-       * if it is not found.
-       */
-      public static _Fields findByThriftIdOrThrow(int fieldId) {
-        _Fields fields = findByThriftId(fieldId);
-        if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
-        return fields;
-      }
-
-      /**
-       * Find the _Fields constant that matches name, or null if its not found.
-       */
-      public static _Fields findByName(String name) {
-        return byName.get(name);
-      }
-
-      private final short _thriftId;
-      private final String _fieldName;
-
-      _Fields(short thriftId, String fieldName) {
-        _thriftId = thriftId;
-        _fieldName = fieldName;
-      }
-
-      public short getThriftFieldId() {
-        return _thriftId;
-      }
-
-      public String getFieldName() {
-        return _fieldName;
-      }
-    }
-
-    // isset id assignments
-    public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
-    static {
-      Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
-      tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataByExprResult.class)));
-      metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_by_expr_result.class, metaDataMap);
-    }
-
-    public get_file_metadata_by_expr_result() {
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(flushCache_result.class, metaDataMap);
     }
 
-    public get_file_metadata_by_expr_result(
-      GetFileMetadataByExprResult success)
-    {
-      this();
-      this.success = success;
+    public flushCache_result() {
     }
 
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public get_file_metadata_by_expr_result(get_file_metadata_by_expr_result other) {
-      if (other.isSetSuccess()) {
-        this.success = new GetFileMetadataByExprResult(other.success);
-      }
+    public flushCache_result(flushCache_result other) {
     }
 
-    public get_file_metadata_by_expr_result deepCopy() {
-      return new get_file_metadata_by_expr_result(this);
+    public flushCache_result deepCopy() {
+      return new flushCache_result(this);
     }
 
     @Override
     public void clear() {
-      this.success = null;
-    }
-
-    public GetFileMetadataByExprResult getSuccess() {
-      return this.success;
-    }
-
-    public void setSuccess(GetFileMetadataByExprResult success) {
-      this.success = success;
-    }
-
-    public void unsetSuccess() {
-      this.success = null;
-    }
-
-    /** Returns true if field success is set (has been assigned a value) and false otherwise */
-    public boolean isSetSuccess() {
-      return this.success != null;
-    }
-
-    public void setSuccessIsSet(boolean value) {
-      if (!value) {
-        this.success = null;
-      }
     }
 
     public void setFieldValue(_Fields field, Object value) {
       switch (field) {
-      case SUCCESS:
-        if (value == null) {
-          unsetSuccess();
-        } else {
-          setSuccess((GetFileMetadataByExprResult)value);
-        }
-        break;
-
       }
     }
 
     public Object getFieldValue(_Fields field) {
       switch (field) {
-      case SUCCESS:
-        return getSuccess();
-
       }
       throw new IllegalStateException();
     }
@@ -170083,8 +169289,6 @@ public class ThriftHiveMetastore {
       }
 
       switch (field) {
-      case SUCCESS:
-        return isSetSuccess();
       }
       throw new IllegalStateException();
     }
@@ -170093,24 +169297,15 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof get_file_metadata_by_expr_result)
-        return this.equals((get_file_metadata_by_expr_result)that);
+      if (that instanceof flushCache_result)
+        return this.equals((flushCache_result)that);
       return false;
     }
 
-    public boolean equals(get_file_metadata_by_expr_result that) {
+    public boolean equals(flushCache_result that) {
       if (that == null)
         return false;
 
-      boolean this_present_success = true && this.isSetSuccess();
-      boolean that_present_success = true && that.isSetSuccess();
-      if (this_present_success || that_present_success) {
-        if (!(this_present_success && that_present_success))
-          return false;
-        if (!this.success.equals(that.success))
-          return false;
-      }
-
       return true;
     }
 
@@ -170118,32 +169313,17 @@ public class ThriftHiveMetastore {
     public int hashCode() {
       List<Object> list = new ArrayList<Object>();
 
-      boolean present_success = true && (isSetSuccess());
-      list.add(present_success);
-      if (present_success)
-        list.add(success);
-
       return list.hashCode();
     }
 
     @Override
-    public int compareTo(get_file_metadata_by_expr_result other) {
+    public int compareTo(flushCache_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-      if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
-        if (lastComparison != 0) {
-          return lastComparison;
-        }
-      }
       return 0;
     }
 
@@ -170161,16 +169341,9 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("get_file_metadata_by_expr_result(");
+      StringBuilder sb = new StringBuilder("flushCache_result(");
       boolean first = true;
 
-      sb.append("success:");
-      if (this.success == null) {
-        sb.append("null");
-      } else {
-        sb.append(this.success);
-      }
-      first = false;
       sb.append(")");
       return sb.toString();
     }
@@ -170178,9 +169351,6 @@ public class ThriftHiveMetastore {
     public void validate() throws org.apache.thrift.TException {
       // check for required fields
       // check for sub-struct validity
-      if (success != null) {
-        success.validate();
-      }
     }
 
     private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
@@ -170199,15 +169369,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class get_file_metadata_by_expr_resultStandardSchemeFactory implements SchemeFactory {
-      public get_file_metadata_by_expr_resultStandardScheme getScheme() {
-        return new get_file_metadata_by_expr_resultStandardScheme();
+    private static class flushCache_resultStandardSchemeFactory implements SchemeFactory {
+      public flushCache_resultStandardScheme getScheme() {
+        return new flushCache_resultStandardScheme();
       }
     }
 
-    private static class get_file_metadata_by_expr_resultStandardScheme extends StandardScheme<get_file_metadata_by_expr_result> {
+    private static class flushCache_resultStandardScheme extends StandardScheme<flushCache_result> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, flushCache_result struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -170217,15 +169387,6 @@ public class ThriftHiveMetastore {
             break;
           }
           switch (schemeField.id) {
-            case 0: // SUCCESS
-              if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.success = new GetFileMetadataByExprResult();
-                struct.success.read(iprot);
-                struct.setSuccessIsSet(true);
-              } else { 
-                org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-              }
-              break;
             default:
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
           }
@@ -170235,68 +169396,49 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, flushCache_result struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
-        if (struct.success != null) {
-          oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
-          struct.success.write(oprot);
-          oprot.writeFieldEnd();
-        }
         oprot.writeFieldStop();
         oprot.writeStructEnd();
       }
 
     }
 
-    private static class get_file_metadata_by_expr_resultTupleSchemeFactory implements SchemeFactory {
-      public get_file_metadata_by_expr_resultTupleScheme getScheme() {
-        return new get_file_metadata_by_expr_resultTupleScheme();
+    private static class flushCache_resultTupleSchemeFactory implements SchemeFactory {
+      public flushCache_resultTupleScheme getScheme() {
+        return new flushCache_resultTupleScheme();
       }
     }
 
-    private static class get_file_metadata_by_expr_resultTupleScheme extends TupleScheme<get_file_metadata_by_expr_result> {
+    private static class flushCache_resultTupleScheme extends TupleScheme<flushCache_result> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, flushCache_result struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
-        BitSet optionals = new BitSet();
-        if (struct.isSetSuccess()) {
-          optionals.set(0);
-        }
-        oprot.writeBitSet(optionals, 1);
-        if (struct.isSetSuccess()) {
-          struct.success.write(oprot);
-        }
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, flushCache_result struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
-        BitSet incoming = iprot.readBitSet(1);
-        if (incoming.get(0)) {
-          struct.success = new GetFileMetadataByExprResult();
-          struct.success.read(iprot);
-          struct.setSuccessIsSet(true);
-        }
       }
     }
 
   }
 
-  public static class get_file_metadata_args implements org.apache.thrift.TBase<get_file_metadata_args, get_file_metadata_args._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_args>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_args");
+  public static class get_file_metadata_by_expr_args implements org.apache.thrift.TBase<get_file_metadata_by_expr_args, get_file_metadata_by_expr_args._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_by_expr_args>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_by_expr_args");
 
     private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new get_file_metadata_argsStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new get_file_metadata_argsTupleSchemeFactory());
+      schemes.put(StandardScheme.class, new get_file_metadata_by_expr_argsStandardSchemeFactory());
+      schemes.put(TupleScheme.class, new get_file_metadata_by_expr_argsTupleSchemeFactory());
     }
 
-    private GetFileMetadataRequest req; // required
+    private GetFileMetadataByExprRequest req; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -170361,16 +169503,16 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       tmpMap.put(_Fields.REQ, new org.apache.thrift.meta_data.FieldMetaData("req", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataRequest.class)));
+          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataByExprRequest.class)));
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_args.class, metaDataMap);
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_by_expr_args.class, metaDataMap);
     }
 
-    public get_file_metadata_args() {
+    public get_file_metadata_by_expr_args() {
     }
 
-    public get_file_metadata_args(
-      GetFileMetadataRequest req)
+    public get_file_metadata_by_expr_args(
+      GetFileMetadataByExprRequest req)
     {
       this();
       this.req = req;
@@ -170379,14 +169521,14 @@ public class ThriftHiveMetastore {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public get_file_metadata_args(get_file_metadata_args other) {
+    public get_file_metadata_by_expr_args(get_file_metadata_by_expr_args other) {
       if (other.isSetReq()) {
-        this.req = new GetFileMetadataRequest(other.req);
+        this.req = new GetFileMetadataByExprRequest(other.req);
       }
     }
 
-    public get_file_metadata_args deepCopy() {
-      return new get_file_metadata_args(this);
+    public get_file_metadata_by_expr_args deepCopy() {
+      return new get_file_metadata_by_expr_args(this);
     }
 
     @Override
@@ -170394,11 +169536,11 @@ public class ThriftHiveMetastore {
       this.req = null;
     }
 
-    public GetFileMetadataRequest getReq() {
+    public GetFileMetadataByExprRequest getReq() {
       return this.req;
     }
 
-    public void setReq(GetFileMetadataRequest req) {
+    public void setReq(GetFileMetadataByExprRequest req) {
       this.req = req;
     }
 
@@ -170423,7 +169565,7 @@ public class ThriftHiveMetastore {
         if (value == null) {
           unsetReq();
         } else {
-          setReq((GetFileMetadataRequest)value);
+          setReq((GetFileMetadataByExprRequest)value);
         }
         break;
 
@@ -170456,12 +169598,12 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof get_file_metadata_args)
-        return this.equals((get_file_metadata_args)that);
+      if (that instanceof get_file_metadata_by_expr_args)
+        return this.equals((get_file_metadata_by_expr_args)that);
       return false;
     }
 
-    public boolean equals(get_file_metadata_args that) {
+    public boolean equals(get_file_metadata_by_expr_args that) {
       if (that == null)
         return false;
 
@@ -170490,7 +169632,7 @@ public class ThriftHiveMetastore {
     }
 
     @Override
-    public int compareTo(get_file_metadata_args other) {
+    public int compareTo(get_file_metadata_by_expr_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
@@ -170524,7 +169666,7 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("get_file_metadata_args(");
+      StringBuilder sb = new StringBuilder("get_file_metadata_by_expr_args(");
       boolean first = true;
 
       sb.append("req:");
@@ -170562,15 +169704,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class get_file_metadata_argsStandardSchemeFactory implements SchemeFactory {
-      public get_file_metadata_argsStandardScheme getScheme() {
-        return new get_file_metadata_argsStandardScheme();
+    private static class get_file_metadata_by_expr_argsStandardSchemeFactory implements SchemeFactory {
+      public get_file_metadata_by_expr_argsStandardScheme getScheme() {
+        return new get_file_metadata_by_expr_argsStandardScheme();
       }
     }
 
-    private static class get_file_metadata_argsStandardScheme extends StandardScheme<get_file_metadata_args> {
+    private static class get_file_metadata_by_expr_argsStandardScheme extends StandardScheme<get_file_metadata_by_expr_args> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -170582,7 +169724,7 @@ public class ThriftHiveMetastore {
           switch (schemeField.id) {
             case 1: // REQ
               if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.req = new GetFileMetadataRequest();
+                struct.req = new GetFileMetadataByExprRequest();
                 struct.req.read(iprot);
                 struct.setReqIsSet(true);
               } else { 
@@ -170598,7 +169740,7 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
@@ -170613,16 +169755,16 @@ public class ThriftHiveMetastore {
 
     }
 
-    private static class get_file_metadata_argsTupleSchemeFactory implements SchemeFactory {
-      public get_file_metadata_argsTupleScheme getScheme() {
-        return new get_file_metadata_argsTupleScheme();
+    private static class get_file_metadata_by_expr_argsTupleSchemeFactory implements SchemeFactory {
+      public get_file_metadata_by_expr_argsTupleScheme getScheme() {
+        return new get_file_metadata_by_expr_argsTupleScheme();
       }
     }
 
-    private static class get_file_metadata_argsTupleScheme extends TupleScheme<get_file_metadata_args> {
+    private static class get_file_metadata_by_expr_argsTupleScheme extends TupleScheme<get_file_metadata_by_expr_args> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
         BitSet optionals = new BitSet();
         if (struct.isSetReq()) {
@@ -170635,11 +169777,11 @@ public class ThriftHiveMetastore {
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_args struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
-          struct.req = new GetFileMetadataRequest();
+          struct.req = new GetFileMetadataByExprRequest();
           struct.req.read(iprot);
           struct.setReqIsSet(true);
         }
@@ -170648,18 +169790,18 @@ public class ThriftHiveMetastore {
 
   }
 
-  public static class get_file_metadata_result implements org.apache.thrift.TBase<get_file_metadata_result, get_file_metadata_result._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_result>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_result");
+  public static class get_file_metadata_by_expr_result implements org.apache.thrift.TBase<get_file_metadata_by_expr_result, get_file_metadata_by_expr_result._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_by_expr_result>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_by_expr_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new get_file_metadata_resultStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new get_file_metadata_resultTupleSchemeFactory());
+      schemes.put(StandardScheme.class, new get_file_metadata_by_expr_resultStandardSchemeFactory());
+      schemes.put(TupleScheme.class, new get_file_metadata_by_expr_resultTupleSchemeFactory());
     }
 
-    private GetFileMetadataResult success; // required
+    private GetFileMetadataByExprResult success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -170724,16 +169866,16 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataResult.class)));
+          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataByExprResult.class)));
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_result.class, metaDataMap);
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_by_expr_result.class, metaDataMap);
     }
 
-    public get_file_metadata_result() {
+    public get_file_metadata_by_expr_result() {
     }
 
-    public get_file_metadata_result(
-      GetFileMetadataResult success)
+    public get_file_metadata_by_expr_result(
+      GetFileMetadataByExprResult success)
     {
       this();
       this.success = success;
@@ -170742,14 +169884,14 @@ public class ThriftHiveMetastore {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public get_file_metadata_result(get_file_metadata_result other) {
+    public get_file_metadata_by_expr_result(get_file_metadata_by_expr_result other) {
       if (other.isSetSuccess()) {
-        this.success = new GetFileMetadataResult(other.success);
+        this.success = new GetFileMetadataByExprResult(other.success);
       }
     }
 
-    public get_file_metadata_result deepCopy() {
-      return new get_file_metadata_result(this);
+    public get_file_metadata_by_expr_result deepCopy() {
+      return new get_file_metadata_by_expr_result(this);
     }
 
     @Override
@@ -170757,11 +169899,11 @@ public class ThriftHiveMetastore {
       this.success = null;
     }
 
-    public GetFileMetadataResult getSuccess() {
+    public GetFileMetadataByExprResult getSuccess() {
       return this.success;
     }
 
-    public void setSuccess(GetFileMetadataResult success) {
+    public void setSuccess(GetFileMetadataByExprResult success) {
       this.success = success;
     }
 
@@ -170786,7 +169928,7 @@ public class ThriftHiveMetastore {
         if (value == null) {
           unsetSuccess();
         } else {
-          setSuccess((GetFileMetadataResult)value);
+          setSuccess((GetFileMetadataByExprResult)value);
         }
         break;
 
@@ -170819,12 +169961,12 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof get_file_metadata_result)
-        return this.equals((get_file_metadata_result)that);
+      if (that instanceof get_file_metadata_by_expr_result)
+        return this.equals((get_file_metadata_by_expr_result)that);
       return false;
     }
 
-    public boolean equals(get_file_metadata_result that) {
+    public boolean equals(get_file_metadata_by_expr_result that) {
       if (that == null)
         return false;
 
@@ -170853,7 +169995,7 @@ public class ThriftHiveMetastore {
     }
 
     @Override
-    public int compareTo(get_file_metadata_result other) {
+    public int compareTo(get_file_metadata_by_expr_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
@@ -170887,7 +170029,7 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("get_file_metadata_result(");
+      StringBuilder sb = new StringBuilder("get_file_metadata_by_expr_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -170925,15 +170067,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class get_file_metadata_resultStandardSchemeFactory implements SchemeFactory {
-      public get_file_metadata_resultStandardScheme getScheme() {
-        return new get_file_metadata_resultStandardScheme();
+    private static class get_file_metadata_by_expr_resultStandardSchemeFactory implements SchemeFactory {
+      public get_file_metadata_by_expr_resultStandardScheme getScheme() {
+        return new get_file_metadata_by_expr_resultStandardScheme();
       }
     }
 
-    private static class get_file_metadata_resultStandardScheme extends StandardScheme<get_file_metadata_result> {
+    private static class get_file_metadata_by_expr_resultStandardScheme extends StandardScheme<get_file_metadata_by_expr_result> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -170945,7 +170087,7 @@ public class ThriftHiveMetastore {
           switch (schemeField.id) {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.success = new GetFileMetadataResult();
+                struct.success = new GetFileMetadataByExprResult();
                 struct.success.read(iprot);
                 struct.setSuccessIsSet(true);
               } else { 
@@ -170961,7 +170103,7 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
@@ -170976,16 +170118,16 @@ public class ThriftHiveMetastore {
 
     }
 
-    private static class get_file_metadata_resultTupleSchemeFactory implements SchemeFactory {
-      public get_file_metadata_resultTupleScheme getScheme() {
-        return new get_file_metadata_resultTupleScheme();
+    private static class get_file_metadata_by_expr_resultTupleSchemeFactory implements SchemeFactory {
+      public get_file_metadata_by_expr_resultTupleScheme getScheme() {
+        return new get_file_metadata_by_expr_resultTupleScheme();
       }
     }
 
-    private static class get_file_metadata_resultTupleScheme extends TupleScheme<get_file_metadata_result> {
+    private static class get_file_metadata_by_expr_resultTupleScheme extends TupleScheme<get_file_metadata_by_expr_result> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
         BitSet optionals = new BitSet();
         if (struct.isSetSuccess()) {
@@ -170998,11 +170140,11 @@ public class ThriftHiveMetastore {
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_by_expr_result struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
-          struct.success = new GetFileMetadataResult();
+          struct.success = new GetFileMetadataByExprResult();
           struct.success.read(iprot);
           struct.setSuccessIsSet(true);
         }
@@ -171011,18 +170153,18 @@ public class ThriftHiveMetastore {
 
   }
 
-  public static class put_file_metadata_args implements org.apache.thrift.TBase<put_file_metadata_args, put_file_metadata_args._Fields>, java.io.Serializable, Cloneable, Comparable<put_file_metadata_args>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("put_file_metadata_args");
+  public static class get_file_metadata_args implements org.apache.thrift.TBase<get_file_metadata_args, get_file_metadata_args._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_args>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_args");
 
     private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new put_file_metadata_argsStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new put_file_metadata_argsTupleSchemeFactory());
+      schemes.put(StandardScheme.class, new get_file_metadata_argsStandardSchemeFactory());
+      schemes.put(TupleScheme.class, new get_file_metadata_argsTupleSchemeFactory());
     }
 
-    private PutFileMetadataRequest req; // required
+    private GetFileMetadataRequest req; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -171087,16 +170229,16 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       tmpMap.put(_Fields.REQ, new org.apache.thrift.meta_data.FieldMetaData("req", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, PutFileMetadataRequest.class)));
+          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataRequest.class)));
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(put_file_metadata_args.class, metaDataMap);
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_args.class, metaDataMap);
     }
 
-    public put_file_metadata_args() {
+    public get_file_metadata_args() {
     }
 
-    public put_file_metadata_args(
-      PutFileMetadataRequest req)
+    public get_file_metadata_args(
+      GetFileMetadataRequest req)
     {
       this();
       this.req = req;
@@ -171105,14 +170247,14 @@ public class ThriftHiveMetastore {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public put_file_metadata_args(put_file_metadata_args other) {
+    public get_file_metadata_args(get_file_metadata_args other) {
       if (other.isSetReq()) {
-        this.req = new PutFileMetadataRequest(other.req);
+        this.req = new GetFileMetadataRequest(other.req);
       }
     }
 
-    public put_file_metadata_args deepCopy() {
-      return new put_file_metadata_args(this);
+    public get_file_metadata_args deepCopy() {
+      return new get_file_metadata_args(this);
     }
 
     @Override
@@ -171120,11 +170262,11 @@ public class ThriftHiveMetastore {
       this.req = null;
     }
 
-    public PutFileMetadataRequest getReq() {
+    public GetFileMetadataRequest getReq() {
       return this.req;
     }
 
-    public void setReq(PutFileMetadataRequest req) {
+    public void setReq(GetFileMetadataRequest req) {
       this.req = req;
     }
 
@@ -171149,7 +170291,7 @@ public class ThriftHiveMetastore {
         if (value == null) {
           unsetReq();
         } else {
-          setReq((PutFileMetadataRequest)value);
+          setReq((GetFileMetadataRequest)value);
         }
         break;
 
@@ -171182,12 +170324,12 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof put_file_metadata_args)
-        return this.equals((put_file_metadata_args)that);
+      if (that instanceof get_file_metadata_args)
+        return this.equals((get_file_metadata_args)that);
       return false;
     }
 
-    public boolean equals(put_file_metadata_args that) {
+    public boolean equals(get_file_metadata_args that) {
       if (that == null)
         return false;
 
@@ -171216,7 +170358,7 @@ public class ThriftHiveMetastore {
     }
 
     @Override
-    public int compareTo(put_file_metadata_args other) {
+    public int compareTo(get_file_metadata_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
@@ -171250,7 +170392,7 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("put_file_metadata_args(");
+      StringBuilder sb = new StringBuilder("get_file_metadata_args(");
       boolean first = true;
 
       sb.append("req:");
@@ -171288,15 +170430,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class put_file_metadata_argsStandardSchemeFactory implements SchemeFactory {
-      public put_file_metadata_argsStandardScheme getScheme() {
-        return new put_file_metadata_argsStandardScheme();
+    private static class get_file_metadata_argsStandardSchemeFactory implements SchemeFactory {
+      public get_file_metadata_argsStandardScheme getScheme() {
+        return new get_file_metadata_argsStandardScheme();
       }
     }
 
-    private static class put_file_metadata_argsStandardScheme extends StandardScheme<put_file_metadata_args> {
+    private static class get_file_metadata_argsStandardScheme extends StandardScheme<get_file_metadata_args> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, put_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -171308,7 +170450,7 @@ public class ThriftHiveMetastore {
           switch (schemeField.id) {
             case 1: // REQ
               if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.req = new PutFileMetadataRequest();
+                struct.req = new GetFileMetadataRequest();
                 struct.req.read(iprot);
                 struct.setReqIsSet(true);
               } else { 
@@ -171324,7 +170466,7 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, put_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_args struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
@@ -171339,16 +170481,16 @@ public class ThriftHiveMetastore {
 
     }
 
-    private static class put_file_metadata_argsTupleSchemeFactory implements SchemeFactory {
-      public put_file_metadata_argsTupleScheme getScheme() {
-        return new put_file_metadata_argsTupleScheme();
+    private static class get_file_metadata_argsTupleSchemeFactory implements SchemeFactory {
+      public get_file_metadata_argsTupleScheme getScheme() {
+        return new get_file_metadata_argsTupleScheme();
       }
     }
 
-    private static class put_file_metadata_argsTupleScheme extends TupleScheme<put_file_metadata_args> {
+    private static class get_file_metadata_argsTupleScheme extends TupleScheme<get_file_metadata_args> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_args struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
         BitSet optionals = new BitSet();
         if (struct.isSetReq()) {
@@ -171361,11 +170503,11 @@ public class ThriftHiveMetastore {
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_args struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
-          struct.req = new PutFileMetadataRequest();
+          struct.req = new GetFileMetadataRequest();
           struct.req.read(iprot);
           struct.setReqIsSet(true);
         }
@@ -171374,18 +170516,18 @@ public class ThriftHiveMetastore {
 
   }
 
-  public static class put_file_metadata_result implements org.apache.thrift.TBase<put_file_metadata_result, put_file_metadata_result._Fields>, java.io.Serializable, Cloneable, Comparable<put_file_metadata_result>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("put_file_metadata_result");
+  public static class get_file_metadata_result implements org.apache.thrift.TBase<get_file_metadata_result, get_file_metadata_result._Fields>, java.io.Serializable, Cloneable, Comparable<get_file_metadata_result>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("get_file_metadata_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new put_file_metadata_resultStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new put_file_metadata_resultTupleSchemeFactory());
+      schemes.put(StandardScheme.class, new get_file_metadata_resultStandardSchemeFactory());
+      schemes.put(TupleScheme.class, new get_file_metadata_resultTupleSchemeFactory());
     }
 
-    private PutFileMetadataResult success; // required
+    private GetFileMetadataResult success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -171450,16 +170592,16 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       tmpMap.put(_Fields.SUCCESS, new org.apache.thrift.meta_data.FieldMetaData("success", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, PutFileMetadataResult.class)));
+          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, GetFileMetadataResult.class)));
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(put_file_metadata_result.class, metaDataMap);
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(get_file_metadata_result.class, metaDataMap);
     }
 
-    public put_file_metadata_result() {
+    public get_file_metadata_result() {
     }
 
-    public put_file_metadata_result(
-      PutFileMetadataResult success)
+    public get_file_metadata_result(
+      GetFileMetadataResult success)
     {
       this();
       this.success = success;
@@ -171468,14 +170610,14 @@ public class ThriftHiveMetastore {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public put_file_metadata_result(put_file_metadata_result other) {
+    public get_file_metadata_result(get_file_metadata_result other) {
       if (other.isSetSuccess()) {
-        this.success = new PutFileMetadataResult(other.success);
+        this.success = new GetFileMetadataResult(other.success);
       }
     }
 
-    public put_file_metadata_result deepCopy() {
-      return new put_file_metadata_result(this);
+    public get_file_metadata_result deepCopy() {
+      return new get_file_metadata_result(this);
     }
 
     @Override
@@ -171483,11 +170625,11 @@ public class ThriftHiveMetastore {
       this.success = null;
     }
 
-    public PutFileMetadataResult getSuccess() {
+    public GetFileMetadataResult getSuccess() {
       return this.success;
     }
 
-    public void setSuccess(PutFileMetadataResult success) {
+    public void setSuccess(GetFileMetadataResult success) {
       this.success = success;
     }
 
@@ -171512,7 +170654,7 @@ public class ThriftHiveMetastore {
         if (value == null) {
           unsetSuccess();
         } else {
-          setSuccess((PutFileMetadataResult)value);
+          setSuccess((GetFileMetadataResult)value);
         }
         break;
 
@@ -171545,12 +170687,12 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof put_file_metadata_result)
-        return this.equals((put_file_metadata_result)that);
+      if (that instanceof get_file_metadata_result)
+        return this.equals((get_file_metadata_result)that);
       return false;
     }
 
-    public boolean equals(put_file_metadata_result that) {
+    public boolean equals(get_file_metadata_result that) {
       if (that == null)
         return false;
 
@@ -171579,7 +170721,7 @@ public class ThriftHiveMetastore {
     }
 
     @Override
-    public int compareTo(put_file_metadata_result other) {
+    public int compareTo(get_file_metadata_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
@@ -171613,7 +170755,7 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("put_file_metadata_result(");
+      StringBuilder sb = new StringBuilder("get_file_metadata_result(");
       boolean first = true;
 
       sb.append("success:");
@@ -171651,15 +170793,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class put_file_metadata_resultStandardSchemeFactory implements SchemeFactory {
-      public put_file_metadata_resultStandardScheme getScheme() {
-        return new put_file_metadata_resultStandardScheme();
+    private static class get_file_metadata_resultStandardSchemeFactory implements SchemeFactory {
+      public get_file_metadata_resultStandardScheme getScheme() {
+        return new get_file_metadata_resultStandardScheme();
       }
     }
 
-    private static class put_file_metadata_resultStandardScheme extends StandardScheme<put_file_metadata_result> {
+    private static class get_file_metadata_resultStandardScheme extends StandardScheme<get_file_metadata_result> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, put_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, get_file_metadata_result struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -171671,7 +170813,7 @@ public class ThriftHiveMetastore {
           switch (schemeField.id) {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.success = new PutFileMetadataResult();
+                struct.success = new GetFileMetadataResult();
                 struct.success.read(iprot);
                 struct.setSuccessIsSet(true);
               } else { 
@@ -171687,7 +170829,7 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, put_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, get_file_metadata_result struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
@@ -171702,16 +170844,16 @@ public class ThriftHiveMetastore {
 
     }
 
-    private static class put_file_metadata_resultTupleSchemeFactory implements SchemeFactory {
-      public put_file_metadata_resultTupleScheme getScheme() {
-        return new put_file_metadata_resultTupleScheme();
+    private static class get_file_metadata_resultTupleSchemeFactory implements SchemeFactory {
+      public get_file_metadata_resultTupleScheme getScheme() {
+        return new get_file_metadata_resultTupleScheme();
       }
     }
 
-    private static class put_file_metadata_resultTupleScheme extends TupleScheme<put_file_metadata_result> {
+    private static class get_file_metadata_resultTupleScheme extends TupleScheme<get_file_metadata_result> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_result struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
         BitSet optionals = new BitSet();
         if (struct.isSetSuccess()) {
@@ -171724,11 +170866,11 @@ public class ThriftHiveMetastore {
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_result struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, get_file_metadata_result struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
-          struct.success = new PutFileMetadataResult();
+          struct.success = new GetFileMetadataResult();
           struct.success.read(iprot);
           struct.setSuccessIsSet(true);
         }
@@ -171737,18 +170879,18 @@ public class ThriftHiveMetastore {
 
   }
 
-  public static class clear_file_metadata_args implements org.apache.thrift.TBase<clear_file_metadata_args, clear_file_metadata_args._Fields>, java.io.Serializable, Cloneable, Comparable<clear_file_metadata_args>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("clear_file_metadata_args");
+  public static class put_file_metadata_args implements org.apache.thrift.TBase<put_file_metadata_args, put_file_metadata_args._Fields>, java.io.Serializable, Cloneable, Comparable<put_file_metadata_args>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("put_file_metadata_args");
 
     private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new clear_file_metadata_argsStandardSchemeFactory());
-      schemes.put(TupleScheme.class, new clear_file_metadata_argsTupleSchemeFactory());
+      schemes.put(StandardScheme.class, new put_file_metadata_argsStandardSchemeFactory());
+      schemes.put(TupleScheme.class, new put_file_metadata_argsTupleSchemeFactory());
     }
 
-    private ClearFileMetadataRequest req; // required
+    private PutFileMetadataRequest req; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
     public enum _Fields implements org.apache.thrift.TFieldIdEnum {
@@ -171813,16 +170955,16 @@ public class ThriftHiveMetastore {
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
       tmpMap.put(_Fields.REQ, new org.apache.thrift.meta_data.FieldMetaData("req", org.apache.thrift.TFieldRequirementType.DEFAULT, 
-          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, ClearFileMetadataRequest.class)));
+          new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, PutFileMetadataRequest.class)));
       metaDataMap = Collections.unmodifiableMap(tmpMap);
-      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(clear_file_metadata_args.class, metaDataMap);
+      org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(put_file_metadata_args.class, metaDataMap);
     }
 
-    public clear_file_metadata_args() {
+    public put_file_metadata_args() {
     }
 
-    public clear_file_metadata_args(
-      ClearFileMetadataRequest req)
+    public put_file_metadata_args(
+      PutFileMetadataRequest req)
     {
       this();
       this.req = req;
@@ -171831,14 +170973,14 @@ public class ThriftHiveMetastore {
     /**
      * Performs a deep copy on <i>other</i>.
      */
-    public clear_file_metadata_args(clear_file_metadata_args other) {
+    public put_file_metadata_args(put_file_metadata_args other) {
       if (other.isSetReq()) {
-        this.req = new ClearFileMetadataRequest(other.req);
+        this.req = new PutFileMetadataRequest(other.req);
       }
     }
 
-    public clear_file_metadata_args deepCopy() {
-      return new clear_file_metadata_args(this);
+    public put_file_metadata_args deepCopy() {
+      return new put_file_metadata_args(this);
     }
 
     @Override
@@ -171846,11 +170988,11 @@ public class ThriftHiveMetastore {
       this.req = null;
     }
 
-    public ClearFileMetadataRequest getReq() {
+    public PutFileMetadataRequest getReq() {
       return this.req;
     }
 
-    public void setReq(ClearFileMetadataRequest req) {
+    public void setReq(PutFileMetadataRequest req) {
       this.req = req;
     }
 
@@ -171875,7 +171017,7 @@ public class ThriftHiveMetastore {
         if (value == null) {
           unsetReq();
         } else {
-          setReq((ClearFileMetadataRequest)value);
+          setReq((PutFileMetadataRequest)value);
         }
         break;
 
@@ -171908,12 +171050,12 @@ public class ThriftHiveMetastore {
     public boolean equals(Object that) {
       if (that == null)
         return false;
-      if (that instanceof clear_file_metadata_args)
-        return this.equals((clear_file_metadata_args)that);
+      if (that instanceof put_file_metadata_args)
+        return this.equals((put_file_metadata_args)that);
       return false;
     }
 
-    public boolean equals(clear_file_metadata_args that) {
+    public boolean equals(put_file_metadata_args that) {
       if (that == null)
         return false;
 
@@ -171942,7 +171084,7 @@ public class ThriftHiveMetastore {
     }
 
     @Override
-    public int compareTo(clear_file_metadata_args other) {
+    public int compareTo(put_file_metadata_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
@@ -171976,7 +171118,7 @@ public class ThriftHiveMetastore {
 
     @Override
     public String toString() {
-      StringBuilder sb = new StringBuilder("clear_file_metadata_args(");
+      StringBuilder sb = new StringBuilder("put_file_metadata_args(");
       boolean first = true;
 
       sb.append("req:");
@@ -172014,15 +171156,15 @@ public class ThriftHiveMetastore {
       }
     }
 
-    private static class clear_file_metadata_argsStandardSchemeFactory implements SchemeFactory {
-      public clear_file_metadata_argsStandardScheme getScheme() {
-        return new clear_file_metadata_argsStandardScheme();
+    private static class put_file_metadata_argsStandardSchemeFactory implements SchemeFactory {
+      public put_file_metadata_argsStandardScheme getScheme() {
+        return new put_file_metadata_argsStandardScheme();
       }
     }
 
-    private static class clear_file_metadata_argsStandardScheme extends StandardScheme<clear_file_metadata_args> {
+    private static class put_file_metadata_argsStandardScheme extends StandardScheme<put_file_metadata_args> {
 
-      public void read(org.apache.thrift.protocol.TProtocol iprot, clear_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol iprot, put_file_metadata_args struct) throws org.apache.thrift.TException {
         org.apache.thrift.protocol.TField schemeField;
         iprot.readStructBegin();
         while (true)
@@ -172034,7 +171176,7 @@ public class ThriftHiveMetastore {
           switch (schemeField.id) {
             case 1: // REQ
               if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
-                struct.req = new ClearFileMetadataRequest();
+                struct.req = new PutFileMetadataRequest();
                 struct.req.read(iprot);
                 struct.setReqIsSet(true);
               } else { 
@@ -172050,7 +171192,7 @@ public class ThriftHiveMetastore {
         struct.validate();
       }
 
-      public void write(org.apache.thrift.protocol.TProtocol oprot, clear_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol oprot, put_file_metadata_args struct) throws org.apache.thrift.TException {
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
@@ -172065,16 +171207,16 @@ public class ThriftHiveMetastore {
 
     }
 
-    private static class clear_file_metadata_argsTupleSchemeFactory implements SchemeFactory {
-      public clear_file_metadata_argsTupleScheme getScheme() {
-        return new clear_file_metadata_argsTupleScheme();
+    private static class put_file_metadata_argsTupleSchemeFactory implements SchemeFactory {
+      public put_file_metadata_argsTupleScheme getScheme() {
+        return new put_file_metadata_argsTupleScheme();
       }
     }
 
-    private static class clear_file_metadata_argsTupleScheme extends TupleScheme<clear_file_metadata_args> {
+    private static class put_file_metadata_argsTupleScheme extends TupleScheme<put_file_metadata_args> {
 
       @Override
-      public void write(org.apache.thrift.protocol.TProtocol prot, clear_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void write(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_args struct) throws org.apache.thrift.TException {
         TTupleProtocol oprot = (TTupleProtocol) prot;
         BitSet optionals = new BitSet();
         if (struct.isSetReq()) {
@@ -172087,11 +171229,11 @@ public class ThriftHiveMetastore {
       }
 
       @Override
-      public void read(org.apache.thrift.protocol.TProtocol prot, clear_file_metadata_args struct) throws org.apache.thrift.TException {
+      public void read(org.apache.thrift.protocol.TProtocol prot, put_file_metadata_args struct) throws org.apache.thrift.TException {
         TTupleProtocol iprot = (TTupleProtocol) prot;
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
-          struct.req = new ClearFileMetadataRequest();
+          struct.req = new PutFileMetadataRequest();
           struct.req.read(iprot);
           struct.setReqIsSet(true);
         }
@@ -172100,18 +171242,18 @@ public class ThriftHiveMetastore {
 
   }
 
-  public static class clear_file_metadata_result implements org.apache.thrift.TBase<clear_file_metadata_result, clear_file_metadata_result._Fields>, java.io.Serializable, Cloneable, Comparable<clear_file_metadata_result>   {
-    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("clear_file_metadata_result");
+  public static class put_file_metadata_result implements org.apache.thrift.TBase<put_file_metadata_result, put_file_metadata_result._Fields>, java.io.Serializable, Cloneable, Comparable<put_file_metadata_result>   {
+    private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("put_file_metadata_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
 
     private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
     static {
-      schemes.put(StandardScheme.class, new clear_file_metadata_resultStandardSchemeFactory());

<TRUNCATED>

[3/5] hive git commit: HIVE-13597 : revert HIVE-12892 (Sergey Shelukhin, reviewed by Ashutosh Chauhan)

Posted by se...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
index 990be15..f731941 100644
--- a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
+++ b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
@@ -168,7 +168,6 @@ class ThriftHiveMetastoreIf : virtual public  ::facebook::fb303::FacebookService
   virtual void put_file_metadata(PutFileMetadataResult& _return, const PutFileMetadataRequest& req) = 0;
   virtual void clear_file_metadata(ClearFileMetadataResult& _return, const ClearFileMetadataRequest& req) = 0;
   virtual void cache_file_metadata(CacheFileMetadataResult& _return, const CacheFileMetadataRequest& req) = 0;
-  virtual void get_change_version(GetChangeVersionResult& _return, const GetChangeVersionRequest& req) = 0;
 };
 
 class ThriftHiveMetastoreIfFactory : virtual public  ::facebook::fb303::FacebookServiceIfFactory {
@@ -664,9 +663,6 @@ class ThriftHiveMetastoreNull : virtual public ThriftHiveMetastoreIf , virtual p
   void cache_file_metadata(CacheFileMetadataResult& /* _return */, const CacheFileMetadataRequest& /* req */) {
     return;
   }
-  void get_change_version(GetChangeVersionResult& /* _return */, const GetChangeVersionRequest& /* req */) {
-    return;
-  }
 };
 
 typedef struct _ThriftHiveMetastore_getMetaConf_args__isset {
@@ -18795,110 +18791,6 @@ class ThriftHiveMetastore_cache_file_metadata_presult {
 
 };
 
-typedef struct _ThriftHiveMetastore_get_change_version_args__isset {
-  _ThriftHiveMetastore_get_change_version_args__isset() : req(false) {}
-  bool req :1;
-} _ThriftHiveMetastore_get_change_version_args__isset;
-
-class ThriftHiveMetastore_get_change_version_args {
- public:
-
-  ThriftHiveMetastore_get_change_version_args(const ThriftHiveMetastore_get_change_version_args&);
-  ThriftHiveMetastore_get_change_version_args& operator=(const ThriftHiveMetastore_get_change_version_args&);
-  ThriftHiveMetastore_get_change_version_args() {
-  }
-
-  virtual ~ThriftHiveMetastore_get_change_version_args() throw();
-  GetChangeVersionRequest req;
-
-  _ThriftHiveMetastore_get_change_version_args__isset __isset;
-
-  void __set_req(const GetChangeVersionRequest& val);
-
-  bool operator == (const ThriftHiveMetastore_get_change_version_args & rhs) const
-  {
-    if (!(req == rhs.req))
-      return false;
-    return true;
-  }
-  bool operator != (const ThriftHiveMetastore_get_change_version_args &rhs) const {
-    return !(*this == rhs);
-  }
-
-  bool operator < (const ThriftHiveMetastore_get_change_version_args & ) const;
-
-  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
-  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
-
-};
-
-
-class ThriftHiveMetastore_get_change_version_pargs {
- public:
-
-
-  virtual ~ThriftHiveMetastore_get_change_version_pargs() throw();
-  const GetChangeVersionRequest* req;
-
-  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
-
-};
-
-typedef struct _ThriftHiveMetastore_get_change_version_result__isset {
-  _ThriftHiveMetastore_get_change_version_result__isset() : success(false) {}
-  bool success :1;
-} _ThriftHiveMetastore_get_change_version_result__isset;
-
-class ThriftHiveMetastore_get_change_version_result {
- public:
-
-  ThriftHiveMetastore_get_change_version_result(const ThriftHiveMetastore_get_change_version_result&);
-  ThriftHiveMetastore_get_change_version_result& operator=(const ThriftHiveMetastore_get_change_version_result&);
-  ThriftHiveMetastore_get_change_version_result() {
-  }
-
-  virtual ~ThriftHiveMetastore_get_change_version_result() throw();
-  GetChangeVersionResult success;
-
-  _ThriftHiveMetastore_get_change_version_result__isset __isset;
-
-  void __set_success(const GetChangeVersionResult& val);
-
-  bool operator == (const ThriftHiveMetastore_get_change_version_result & rhs) const
-  {
-    if (!(success == rhs.success))
-      return false;
-    return true;
-  }
-  bool operator != (const ThriftHiveMetastore_get_change_version_result &rhs) const {
-    return !(*this == rhs);
-  }
-
-  bool operator < (const ThriftHiveMetastore_get_change_version_result & ) const;
-
-  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
-  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
-
-};
-
-typedef struct _ThriftHiveMetastore_get_change_version_presult__isset {
-  _ThriftHiveMetastore_get_change_version_presult__isset() : success(false) {}
-  bool success :1;
-} _ThriftHiveMetastore_get_change_version_presult__isset;
-
-class ThriftHiveMetastore_get_change_version_presult {
- public:
-
-
-  virtual ~ThriftHiveMetastore_get_change_version_presult() throw();
-  GetChangeVersionResult* success;
-
-  _ThriftHiveMetastore_get_change_version_presult__isset __isset;
-
-  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
-
-};
-
 class ThriftHiveMetastoreClient : virtual public ThriftHiveMetastoreIf, public  ::facebook::fb303::FacebookServiceClient {
  public:
   ThriftHiveMetastoreClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> prot) :
@@ -19348,9 +19240,6 @@ class ThriftHiveMetastoreClient : virtual public ThriftHiveMetastoreIf, public
   void cache_file_metadata(CacheFileMetadataResult& _return, const CacheFileMetadataRequest& req);
   void send_cache_file_metadata(const CacheFileMetadataRequest& req);
   void recv_cache_file_metadata(CacheFileMetadataResult& _return);
-  void get_change_version(GetChangeVersionResult& _return, const GetChangeVersionRequest& req);
-  void send_get_change_version(const GetChangeVersionRequest& req);
-  void recv_get_change_version(GetChangeVersionResult& _return);
 };
 
 class ThriftHiveMetastoreProcessor : public  ::facebook::fb303::FacebookServiceProcessor {
@@ -19507,7 +19396,6 @@ class ThriftHiveMetastoreProcessor : public  ::facebook::fb303::FacebookServiceP
   void process_put_file_metadata(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_clear_file_metadata(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_cache_file_metadata(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
-  void process_get_change_version(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
  public:
   ThriftHiveMetastoreProcessor(boost::shared_ptr<ThriftHiveMetastoreIf> iface) :
      ::facebook::fb303::FacebookServiceProcessor(iface),
@@ -19658,7 +19546,6 @@ class ThriftHiveMetastoreProcessor : public  ::facebook::fb303::FacebookServiceP
     processMap_["put_file_metadata"] = &ThriftHiveMetastoreProcessor::process_put_file_metadata;
     processMap_["clear_file_metadata"] = &ThriftHiveMetastoreProcessor::process_clear_file_metadata;
     processMap_["cache_file_metadata"] = &ThriftHiveMetastoreProcessor::process_cache_file_metadata;
-    processMap_["get_change_version"] = &ThriftHiveMetastoreProcessor::process_get_change_version;
   }
 
   virtual ~ThriftHiveMetastoreProcessor() {}
@@ -21092,16 +20979,6 @@ class ThriftHiveMetastoreMultiface : virtual public ThriftHiveMetastoreIf, publi
     return;
   }
 
-  void get_change_version(GetChangeVersionResult& _return, const GetChangeVersionRequest& req) {
-    size_t sz = ifaces_.size();
-    size_t i = 0;
-    for (; i < (sz - 1); ++i) {
-      ifaces_[i]->get_change_version(_return, req);
-    }
-    ifaces_[i]->get_change_version(_return, req);
-    return;
-  }
-
 };
 
 // The 'concurrent' client is a thread safe client that correctly handles
@@ -21556,9 +21433,6 @@ class ThriftHiveMetastoreConcurrentClient : virtual public ThriftHiveMetastoreIf
   void cache_file_metadata(CacheFileMetadataResult& _return, const CacheFileMetadataRequest& req);
   int32_t send_cache_file_metadata(const CacheFileMetadataRequest& req);
   void recv_cache_file_metadata(CacheFileMetadataResult& _return, const int32_t seqid);
-  void get_change_version(GetChangeVersionResult& _return, const GetChangeVersionRequest& req);
-  int32_t send_get_change_version(const GetChangeVersionRequest& req);
-  void recv_get_change_version(GetChangeVersionResult& _return, const int32_t seqid);
 };
 
 #ifdef _WIN32

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
index 2d13e77..1fd8d36 100644
--- a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
@@ -752,11 +752,6 @@ class ThriftHiveMetastoreHandler : virtual public ThriftHiveMetastoreIf {
     printf("cache_file_metadata\n");
   }
 
-  void get_change_version(GetChangeVersionResult& _return, const GetChangeVersionRequest& req) {
-    // Your implementation goes here
-    printf("get_change_version\n");
-  }
-
 };
 
 int main(int argc, char **argv) {

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
index 36a0f96..82d8686 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
@@ -15806,178 +15806,6 @@ void FireEventResponse::printTo(std::ostream& out) const {
 }
 
 
-GetChangeVersionRequest::~GetChangeVersionRequest() throw() {
-}
-
-
-void GetChangeVersionRequest::__set_topic(const std::string& val) {
-  this->topic = val;
-}
-
-uint32_t GetChangeVersionRequest::read(::apache::thrift::protocol::TProtocol* iprot) {
-
-  apache::thrift::protocol::TInputRecursionTracker tracker(*iprot);
-  uint32_t xfer = 0;
-  std::string fname;
-  ::apache::thrift::protocol::TType ftype;
-  int16_t fid;
-
-  xfer += iprot->readStructBegin(fname);
-
-  using ::apache::thrift::protocol::TProtocolException;
-
-  bool isset_topic = false;
-
-  while (true)
-  {
-    xfer += iprot->readFieldBegin(fname, ftype, fid);
-    if (ftype == ::apache::thrift::protocol::T_STOP) {
-      break;
-    }
-    switch (fid)
-    {
-      case 1:
-        if (ftype == ::apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->topic);
-          isset_topic = true;
-        } else {
-          xfer += iprot->skip(ftype);
-        }
-        break;
-      default:
-        xfer += iprot->skip(ftype);
-        break;
-    }
-    xfer += iprot->readFieldEnd();
-  }
-
-  xfer += iprot->readStructEnd();
-
-  if (!isset_topic)
-    throw TProtocolException(TProtocolException::INVALID_DATA);
-  return xfer;
-}
-
-uint32_t GetChangeVersionRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
-  uint32_t xfer = 0;
-  apache::thrift::protocol::TOutputRecursionTracker tracker(*oprot);
-  xfer += oprot->writeStructBegin("GetChangeVersionRequest");
-
-  xfer += oprot->writeFieldBegin("topic", ::apache::thrift::protocol::T_STRING, 1);
-  xfer += oprot->writeString(this->topic);
-  xfer += oprot->writeFieldEnd();
-
-  xfer += oprot->writeFieldStop();
-  xfer += oprot->writeStructEnd();
-  return xfer;
-}
-
-void swap(GetChangeVersionRequest &a, GetChangeVersionRequest &b) {
-  using ::std::swap;
-  swap(a.topic, b.topic);
-}
-
-GetChangeVersionRequest::GetChangeVersionRequest(const GetChangeVersionRequest& other635) {
-  topic = other635.topic;
-}
-GetChangeVersionRequest& GetChangeVersionRequest::operator=(const GetChangeVersionRequest& other636) {
-  topic = other636.topic;
-  return *this;
-}
-void GetChangeVersionRequest::printTo(std::ostream& out) const {
-  using ::apache::thrift::to_string;
-  out << "GetChangeVersionRequest(";
-  out << "topic=" << to_string(topic);
-  out << ")";
-}
-
-
-GetChangeVersionResult::~GetChangeVersionResult() throw() {
-}
-
-
-void GetChangeVersionResult::__set_version(const int64_t val) {
-  this->version = val;
-}
-
-uint32_t GetChangeVersionResult::read(::apache::thrift::protocol::TProtocol* iprot) {
-
-  apache::thrift::protocol::TInputRecursionTracker tracker(*iprot);
-  uint32_t xfer = 0;
-  std::string fname;
-  ::apache::thrift::protocol::TType ftype;
-  int16_t fid;
-
-  xfer += iprot->readStructBegin(fname);
-
-  using ::apache::thrift::protocol::TProtocolException;
-
-  bool isset_version = false;
-
-  while (true)
-  {
-    xfer += iprot->readFieldBegin(fname, ftype, fid);
-    if (ftype == ::apache::thrift::protocol::T_STOP) {
-      break;
-    }
-    switch (fid)
-    {
-      case 1:
-        if (ftype == ::apache::thrift::protocol::T_I64) {
-          xfer += iprot->readI64(this->version);
-          isset_version = true;
-        } else {
-          xfer += iprot->skip(ftype);
-        }
-        break;
-      default:
-        xfer += iprot->skip(ftype);
-        break;
-    }
-    xfer += iprot->readFieldEnd();
-  }
-
-  xfer += iprot->readStructEnd();
-
-  if (!isset_version)
-    throw TProtocolException(TProtocolException::INVALID_DATA);
-  return xfer;
-}
-
-uint32_t GetChangeVersionResult::write(::apache::thrift::protocol::TProtocol* oprot) const {
-  uint32_t xfer = 0;
-  apache::thrift::protocol::TOutputRecursionTracker tracker(*oprot);
-  xfer += oprot->writeStructBegin("GetChangeVersionResult");
-
-  xfer += oprot->writeFieldBegin("version", ::apache::thrift::protocol::T_I64, 1);
-  xfer += oprot->writeI64(this->version);
-  xfer += oprot->writeFieldEnd();
-
-  xfer += oprot->writeFieldStop();
-  xfer += oprot->writeStructEnd();
-  return xfer;
-}
-
-void swap(GetChangeVersionResult &a, GetChangeVersionResult &b) {
-  using ::std::swap;
-  swap(a.version, b.version);
-}
-
-GetChangeVersionResult::GetChangeVersionResult(const GetChangeVersionResult& other637) {
-  version = other637.version;
-}
-GetChangeVersionResult& GetChangeVersionResult::operator=(const GetChangeVersionResult& other638) {
-  version = other638.version;
-  return *this;
-}
-void GetChangeVersionResult::printTo(std::ostream& out) const {
-  using ::apache::thrift::to_string;
-  out << "GetChangeVersionResult(";
-  out << "version=" << to_string(version);
-  out << ")";
-}
-
-
 MetadataPpdResult::~MetadataPpdResult() throw() {
 }
 
@@ -16068,15 +15896,15 @@ void swap(MetadataPpdResult &a, MetadataPpdResult &b) {
   swap(a.__isset, b.__isset);
 }
 
-MetadataPpdResult::MetadataPpdResult(const MetadataPpdResult& other639) {
-  metadata = other639.metadata;
-  includeBitset = other639.includeBitset;
-  __isset = other639.__isset;
+MetadataPpdResult::MetadataPpdResult(const MetadataPpdResult& other635) {
+  metadata = other635.metadata;
+  includeBitset = other635.includeBitset;
+  __isset = other635.__isset;
 }
-MetadataPpdResult& MetadataPpdResult::operator=(const MetadataPpdResult& other640) {
-  metadata = other640.metadata;
-  includeBitset = other640.includeBitset;
-  __isset = other640.__isset;
+MetadataPpdResult& MetadataPpdResult::operator=(const MetadataPpdResult& other636) {
+  metadata = other636.metadata;
+  includeBitset = other636.includeBitset;
+  __isset = other636.__isset;
   return *this;
 }
 void MetadataPpdResult::printTo(std::ostream& out) const {
@@ -16127,17 +15955,17 @@ uint32_t GetFileMetadataByExprResult::read(::apache::thrift::protocol::TProtocol
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->metadata.clear();
-            uint32_t _size641;
-            ::apache::thrift::protocol::TType _ktype642;
-            ::apache::thrift::protocol::TType _vtype643;
-            xfer += iprot->readMapBegin(_ktype642, _vtype643, _size641);
-            uint32_t _i645;
-            for (_i645 = 0; _i645 < _size641; ++_i645)
+            uint32_t _size637;
+            ::apache::thrift::protocol::TType _ktype638;
+            ::apache::thrift::protocol::TType _vtype639;
+            xfer += iprot->readMapBegin(_ktype638, _vtype639, _size637);
+            uint32_t _i641;
+            for (_i641 = 0; _i641 < _size637; ++_i641)
             {
-              int64_t _key646;
-              xfer += iprot->readI64(_key646);
-              MetadataPpdResult& _val647 = this->metadata[_key646];
-              xfer += _val647.read(iprot);
+              int64_t _key642;
+              xfer += iprot->readI64(_key642);
+              MetadataPpdResult& _val643 = this->metadata[_key642];
+              xfer += _val643.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -16178,11 +16006,11 @@ uint32_t GetFileMetadataByExprResult::write(::apache::thrift::protocol::TProtoco
   xfer += oprot->writeFieldBegin("metadata", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I64, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->metadata.size()));
-    std::map<int64_t, MetadataPpdResult> ::const_iterator _iter648;
-    for (_iter648 = this->metadata.begin(); _iter648 != this->metadata.end(); ++_iter648)
+    std::map<int64_t, MetadataPpdResult> ::const_iterator _iter644;
+    for (_iter644 = this->metadata.begin(); _iter644 != this->metadata.end(); ++_iter644)
     {
-      xfer += oprot->writeI64(_iter648->first);
-      xfer += _iter648->second.write(oprot);
+      xfer += oprot->writeI64(_iter644->first);
+      xfer += _iter644->second.write(oprot);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -16203,13 +16031,13 @@ void swap(GetFileMetadataByExprResult &a, GetFileMetadataByExprResult &b) {
   swap(a.isSupported, b.isSupported);
 }
 
-GetFileMetadataByExprResult::GetFileMetadataByExprResult(const GetFileMetadataByExprResult& other649) {
-  metadata = other649.metadata;
-  isSupported = other649.isSupported;
+GetFileMetadataByExprResult::GetFileMetadataByExprResult(const GetFileMetadataByExprResult& other645) {
+  metadata = other645.metadata;
+  isSupported = other645.isSupported;
 }
-GetFileMetadataByExprResult& GetFileMetadataByExprResult::operator=(const GetFileMetadataByExprResult& other650) {
-  metadata = other650.metadata;
-  isSupported = other650.isSupported;
+GetFileMetadataByExprResult& GetFileMetadataByExprResult::operator=(const GetFileMetadataByExprResult& other646) {
+  metadata = other646.metadata;
+  isSupported = other646.isSupported;
   return *this;
 }
 void GetFileMetadataByExprResult::printTo(std::ostream& out) const {
@@ -16270,14 +16098,14 @@ uint32_t GetFileMetadataByExprRequest::read(::apache::thrift::protocol::TProtoco
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->fileIds.clear();
-            uint32_t _size651;
-            ::apache::thrift::protocol::TType _etype654;
-            xfer += iprot->readListBegin(_etype654, _size651);
-            this->fileIds.resize(_size651);
-            uint32_t _i655;
-            for (_i655 = 0; _i655 < _size651; ++_i655)
+            uint32_t _size647;
+            ::apache::thrift::protocol::TType _etype650;
+            xfer += iprot->readListBegin(_etype650, _size647);
+            this->fileIds.resize(_size647);
+            uint32_t _i651;
+            for (_i651 = 0; _i651 < _size647; ++_i651)
             {
-              xfer += iprot->readI64(this->fileIds[_i655]);
+              xfer += iprot->readI64(this->fileIds[_i651]);
             }
             xfer += iprot->readListEnd();
           }
@@ -16304,9 +16132,9 @@ uint32_t GetFileMetadataByExprRequest::read(::apache::thrift::protocol::TProtoco
         break;
       case 4:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast656;
-          xfer += iprot->readI32(ecast656);
-          this->type = (FileMetadataExprType::type)ecast656;
+          int32_t ecast652;
+          xfer += iprot->readI32(ecast652);
+          this->type = (FileMetadataExprType::type)ecast652;
           this->__isset.type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -16336,10 +16164,10 @@ uint32_t GetFileMetadataByExprRequest::write(::apache::thrift::protocol::TProtoc
   xfer += oprot->writeFieldBegin("fileIds", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->fileIds.size()));
-    std::vector<int64_t> ::const_iterator _iter657;
-    for (_iter657 = this->fileIds.begin(); _iter657 != this->fileIds.end(); ++_iter657)
+    std::vector<int64_t> ::const_iterator _iter653;
+    for (_iter653 = this->fileIds.begin(); _iter653 != this->fileIds.end(); ++_iter653)
     {
-      xfer += oprot->writeI64((*_iter657));
+      xfer += oprot->writeI64((*_iter653));
     }
     xfer += oprot->writeListEnd();
   }
@@ -16373,19 +16201,19 @@ void swap(GetFileMetadataByExprRequest &a, GetFileMetadataByExprRequest &b) {
   swap(a.__isset, b.__isset);
 }
 
-GetFileMetadataByExprRequest::GetFileMetadataByExprRequest(const GetFileMetadataByExprRequest& other658) {
-  fileIds = other658.fileIds;
-  expr = other658.expr;
-  doGetFooters = other658.doGetFooters;
-  type = other658.type;
-  __isset = other658.__isset;
+GetFileMetadataByExprRequest::GetFileMetadataByExprRequest(const GetFileMetadataByExprRequest& other654) {
+  fileIds = other654.fileIds;
+  expr = other654.expr;
+  doGetFooters = other654.doGetFooters;
+  type = other654.type;
+  __isset = other654.__isset;
 }
-GetFileMetadataByExprRequest& GetFileMetadataByExprRequest::operator=(const GetFileMetadataByExprRequest& other659) {
-  fileIds = other659.fileIds;
-  expr = other659.expr;
-  doGetFooters = other659.doGetFooters;
-  type = other659.type;
-  __isset = other659.__isset;
+GetFileMetadataByExprRequest& GetFileMetadataByExprRequest::operator=(const GetFileMetadataByExprRequest& other655) {
+  fileIds = other655.fileIds;
+  expr = other655.expr;
+  doGetFooters = other655.doGetFooters;
+  type = other655.type;
+  __isset = other655.__isset;
   return *this;
 }
 void GetFileMetadataByExprRequest::printTo(std::ostream& out) const {
@@ -16438,17 +16266,17 @@ uint32_t GetFileMetadataResult::read(::apache::thrift::protocol::TProtocol* ipro
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->metadata.clear();
-            uint32_t _size660;
-            ::apache::thrift::protocol::TType _ktype661;
-            ::apache::thrift::protocol::TType _vtype662;
-            xfer += iprot->readMapBegin(_ktype661, _vtype662, _size660);
-            uint32_t _i664;
-            for (_i664 = 0; _i664 < _size660; ++_i664)
+            uint32_t _size656;
+            ::apache::thrift::protocol::TType _ktype657;
+            ::apache::thrift::protocol::TType _vtype658;
+            xfer += iprot->readMapBegin(_ktype657, _vtype658, _size656);
+            uint32_t _i660;
+            for (_i660 = 0; _i660 < _size656; ++_i660)
             {
-              int64_t _key665;
-              xfer += iprot->readI64(_key665);
-              std::string& _val666 = this->metadata[_key665];
-              xfer += iprot->readBinary(_val666);
+              int64_t _key661;
+              xfer += iprot->readI64(_key661);
+              std::string& _val662 = this->metadata[_key661];
+              xfer += iprot->readBinary(_val662);
             }
             xfer += iprot->readMapEnd();
           }
@@ -16489,11 +16317,11 @@ uint32_t GetFileMetadataResult::write(::apache::thrift::protocol::TProtocol* opr
   xfer += oprot->writeFieldBegin("metadata", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I64, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->metadata.size()));
-    std::map<int64_t, std::string> ::const_iterator _iter667;
-    for (_iter667 = this->metadata.begin(); _iter667 != this->metadata.end(); ++_iter667)
+    std::map<int64_t, std::string> ::const_iterator _iter663;
+    for (_iter663 = this->metadata.begin(); _iter663 != this->metadata.end(); ++_iter663)
     {
-      xfer += oprot->writeI64(_iter667->first);
-      xfer += oprot->writeBinary(_iter667->second);
+      xfer += oprot->writeI64(_iter663->first);
+      xfer += oprot->writeBinary(_iter663->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -16514,13 +16342,13 @@ void swap(GetFileMetadataResult &a, GetFileMetadataResult &b) {
   swap(a.isSupported, b.isSupported);
 }
 
-GetFileMetadataResult::GetFileMetadataResult(const GetFileMetadataResult& other668) {
-  metadata = other668.metadata;
-  isSupported = other668.isSupported;
+GetFileMetadataResult::GetFileMetadataResult(const GetFileMetadataResult& other664) {
+  metadata = other664.metadata;
+  isSupported = other664.isSupported;
 }
-GetFileMetadataResult& GetFileMetadataResult::operator=(const GetFileMetadataResult& other669) {
-  metadata = other669.metadata;
-  isSupported = other669.isSupported;
+GetFileMetadataResult& GetFileMetadataResult::operator=(const GetFileMetadataResult& other665) {
+  metadata = other665.metadata;
+  isSupported = other665.isSupported;
   return *this;
 }
 void GetFileMetadataResult::printTo(std::ostream& out) const {
@@ -16566,14 +16394,14 @@ uint32_t GetFileMetadataRequest::read(::apache::thrift::protocol::TProtocol* ipr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->fileIds.clear();
-            uint32_t _size670;
-            ::apache::thrift::protocol::TType _etype673;
-            xfer += iprot->readListBegin(_etype673, _size670);
-            this->fileIds.resize(_size670);
-            uint32_t _i674;
-            for (_i674 = 0; _i674 < _size670; ++_i674)
+            uint32_t _size666;
+            ::apache::thrift::protocol::TType _etype669;
+            xfer += iprot->readListBegin(_etype669, _size666);
+            this->fileIds.resize(_size666);
+            uint32_t _i670;
+            for (_i670 = 0; _i670 < _size666; ++_i670)
             {
-              xfer += iprot->readI64(this->fileIds[_i674]);
+              xfer += iprot->readI64(this->fileIds[_i670]);
             }
             xfer += iprot->readListEnd();
           }
@@ -16604,10 +16432,10 @@ uint32_t GetFileMetadataRequest::write(::apache::thrift::protocol::TProtocol* op
   xfer += oprot->writeFieldBegin("fileIds", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->fileIds.size()));
-    std::vector<int64_t> ::const_iterator _iter675;
-    for (_iter675 = this->fileIds.begin(); _iter675 != this->fileIds.end(); ++_iter675)
+    std::vector<int64_t> ::const_iterator _iter671;
+    for (_iter671 = this->fileIds.begin(); _iter671 != this->fileIds.end(); ++_iter671)
     {
-      xfer += oprot->writeI64((*_iter675));
+      xfer += oprot->writeI64((*_iter671));
     }
     xfer += oprot->writeListEnd();
   }
@@ -16623,11 +16451,11 @@ void swap(GetFileMetadataRequest &a, GetFileMetadataRequest &b) {
   swap(a.fileIds, b.fileIds);
 }
 
-GetFileMetadataRequest::GetFileMetadataRequest(const GetFileMetadataRequest& other676) {
-  fileIds = other676.fileIds;
+GetFileMetadataRequest::GetFileMetadataRequest(const GetFileMetadataRequest& other672) {
+  fileIds = other672.fileIds;
 }
-GetFileMetadataRequest& GetFileMetadataRequest::operator=(const GetFileMetadataRequest& other677) {
-  fileIds = other677.fileIds;
+GetFileMetadataRequest& GetFileMetadataRequest::operator=(const GetFileMetadataRequest& other673) {
+  fileIds = other673.fileIds;
   return *this;
 }
 void GetFileMetadataRequest::printTo(std::ostream& out) const {
@@ -16686,11 +16514,11 @@ void swap(PutFileMetadataResult &a, PutFileMetadataResult &b) {
   (void) b;
 }
 
-PutFileMetadataResult::PutFileMetadataResult(const PutFileMetadataResult& other678) {
-  (void) other678;
+PutFileMetadataResult::PutFileMetadataResult(const PutFileMetadataResult& other674) {
+  (void) other674;
 }
-PutFileMetadataResult& PutFileMetadataResult::operator=(const PutFileMetadataResult& other679) {
-  (void) other679;
+PutFileMetadataResult& PutFileMetadataResult::operator=(const PutFileMetadataResult& other675) {
+  (void) other675;
   return *this;
 }
 void PutFileMetadataResult::printTo(std::ostream& out) const {
@@ -16744,14 +16572,14 @@ uint32_t PutFileMetadataRequest::read(::apache::thrift::protocol::TProtocol* ipr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->fileIds.clear();
-            uint32_t _size680;
-            ::apache::thrift::protocol::TType _etype683;
-            xfer += iprot->readListBegin(_etype683, _size680);
-            this->fileIds.resize(_size680);
-            uint32_t _i684;
-            for (_i684 = 0; _i684 < _size680; ++_i684)
+            uint32_t _size676;
+            ::apache::thrift::protocol::TType _etype679;
+            xfer += iprot->readListBegin(_etype679, _size676);
+            this->fileIds.resize(_size676);
+            uint32_t _i680;
+            for (_i680 = 0; _i680 < _size676; ++_i680)
             {
-              xfer += iprot->readI64(this->fileIds[_i684]);
+              xfer += iprot->readI64(this->fileIds[_i680]);
             }
             xfer += iprot->readListEnd();
           }
@@ -16764,14 +16592,14 @@ uint32_t PutFileMetadataRequest::read(::apache::thrift::protocol::TProtocol* ipr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->metadata.clear();
-            uint32_t _size685;
-            ::apache::thrift::protocol::TType _etype688;
-            xfer += iprot->readListBegin(_etype688, _size685);
-            this->metadata.resize(_size685);
-            uint32_t _i689;
-            for (_i689 = 0; _i689 < _size685; ++_i689)
+            uint32_t _size681;
+            ::apache::thrift::protocol::TType _etype684;
+            xfer += iprot->readListBegin(_etype684, _size681);
+            this->metadata.resize(_size681);
+            uint32_t _i685;
+            for (_i685 = 0; _i685 < _size681; ++_i685)
             {
-              xfer += iprot->readBinary(this->metadata[_i689]);
+              xfer += iprot->readBinary(this->metadata[_i685]);
             }
             xfer += iprot->readListEnd();
           }
@@ -16782,9 +16610,9 @@ uint32_t PutFileMetadataRequest::read(::apache::thrift::protocol::TProtocol* ipr
         break;
       case 3:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast690;
-          xfer += iprot->readI32(ecast690);
-          this->type = (FileMetadataExprType::type)ecast690;
+          int32_t ecast686;
+          xfer += iprot->readI32(ecast686);
+          this->type = (FileMetadataExprType::type)ecast686;
           this->__isset.type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -16814,10 +16642,10 @@ uint32_t PutFileMetadataRequest::write(::apache::thrift::protocol::TProtocol* op
   xfer += oprot->writeFieldBegin("fileIds", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->fileIds.size()));
-    std::vector<int64_t> ::const_iterator _iter691;
-    for (_iter691 = this->fileIds.begin(); _iter691 != this->fileIds.end(); ++_iter691)
+    std::vector<int64_t> ::const_iterator _iter687;
+    for (_iter687 = this->fileIds.begin(); _iter687 != this->fileIds.end(); ++_iter687)
     {
-      xfer += oprot->writeI64((*_iter691));
+      xfer += oprot->writeI64((*_iter687));
     }
     xfer += oprot->writeListEnd();
   }
@@ -16826,10 +16654,10 @@ uint32_t PutFileMetadataRequest::write(::apache::thrift::protocol::TProtocol* op
   xfer += oprot->writeFieldBegin("metadata", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->metadata.size()));
-    std::vector<std::string> ::const_iterator _iter692;
-    for (_iter692 = this->metadata.begin(); _iter692 != this->metadata.end(); ++_iter692)
+    std::vector<std::string> ::const_iterator _iter688;
+    for (_iter688 = this->metadata.begin(); _iter688 != this->metadata.end(); ++_iter688)
     {
-      xfer += oprot->writeBinary((*_iter692));
+      xfer += oprot->writeBinary((*_iter688));
     }
     xfer += oprot->writeListEnd();
   }
@@ -16853,17 +16681,17 @@ void swap(PutFileMetadataRequest &a, PutFileMetadataRequest &b) {
   swap(a.__isset, b.__isset);
 }
 
-PutFileMetadataRequest::PutFileMetadataRequest(const PutFileMetadataRequest& other693) {
-  fileIds = other693.fileIds;
-  metadata = other693.metadata;
-  type = other693.type;
-  __isset = other693.__isset;
+PutFileMetadataRequest::PutFileMetadataRequest(const PutFileMetadataRequest& other689) {
+  fileIds = other689.fileIds;
+  metadata = other689.metadata;
+  type = other689.type;
+  __isset = other689.__isset;
 }
-PutFileMetadataRequest& PutFileMetadataRequest::operator=(const PutFileMetadataRequest& other694) {
-  fileIds = other694.fileIds;
-  metadata = other694.metadata;
-  type = other694.type;
-  __isset = other694.__isset;
+PutFileMetadataRequest& PutFileMetadataRequest::operator=(const PutFileMetadataRequest& other690) {
+  fileIds = other690.fileIds;
+  metadata = other690.metadata;
+  type = other690.type;
+  __isset = other690.__isset;
   return *this;
 }
 void PutFileMetadataRequest::printTo(std::ostream& out) const {
@@ -16924,11 +16752,11 @@ void swap(ClearFileMetadataResult &a, ClearFileMetadataResult &b) {
   (void) b;
 }
 
-ClearFileMetadataResult::ClearFileMetadataResult(const ClearFileMetadataResult& other695) {
-  (void) other695;
+ClearFileMetadataResult::ClearFileMetadataResult(const ClearFileMetadataResult& other691) {
+  (void) other691;
 }
-ClearFileMetadataResult& ClearFileMetadataResult::operator=(const ClearFileMetadataResult& other696) {
-  (void) other696;
+ClearFileMetadataResult& ClearFileMetadataResult::operator=(const ClearFileMetadataResult& other692) {
+  (void) other692;
   return *this;
 }
 void ClearFileMetadataResult::printTo(std::ostream& out) const {
@@ -16972,14 +16800,14 @@ uint32_t ClearFileMetadataRequest::read(::apache::thrift::protocol::TProtocol* i
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->fileIds.clear();
-            uint32_t _size697;
-            ::apache::thrift::protocol::TType _etype700;
-            xfer += iprot->readListBegin(_etype700, _size697);
-            this->fileIds.resize(_size697);
-            uint32_t _i701;
-            for (_i701 = 0; _i701 < _size697; ++_i701)
+            uint32_t _size693;
+            ::apache::thrift::protocol::TType _etype696;
+            xfer += iprot->readListBegin(_etype696, _size693);
+            this->fileIds.resize(_size693);
+            uint32_t _i697;
+            for (_i697 = 0; _i697 < _size693; ++_i697)
             {
-              xfer += iprot->readI64(this->fileIds[_i701]);
+              xfer += iprot->readI64(this->fileIds[_i697]);
             }
             xfer += iprot->readListEnd();
           }
@@ -17010,10 +16838,10 @@ uint32_t ClearFileMetadataRequest::write(::apache::thrift::protocol::TProtocol*
   xfer += oprot->writeFieldBegin("fileIds", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->fileIds.size()));
-    std::vector<int64_t> ::const_iterator _iter702;
-    for (_iter702 = this->fileIds.begin(); _iter702 != this->fileIds.end(); ++_iter702)
+    std::vector<int64_t> ::const_iterator _iter698;
+    for (_iter698 = this->fileIds.begin(); _iter698 != this->fileIds.end(); ++_iter698)
     {
-      xfer += oprot->writeI64((*_iter702));
+      xfer += oprot->writeI64((*_iter698));
     }
     xfer += oprot->writeListEnd();
   }
@@ -17029,11 +16857,11 @@ void swap(ClearFileMetadataRequest &a, ClearFileMetadataRequest &b) {
   swap(a.fileIds, b.fileIds);
 }
 
-ClearFileMetadataRequest::ClearFileMetadataRequest(const ClearFileMetadataRequest& other703) {
-  fileIds = other703.fileIds;
+ClearFileMetadataRequest::ClearFileMetadataRequest(const ClearFileMetadataRequest& other699) {
+  fileIds = other699.fileIds;
 }
-ClearFileMetadataRequest& ClearFileMetadataRequest::operator=(const ClearFileMetadataRequest& other704) {
-  fileIds = other704.fileIds;
+ClearFileMetadataRequest& ClearFileMetadataRequest::operator=(const ClearFileMetadataRequest& other700) {
+  fileIds = other700.fileIds;
   return *this;
 }
 void ClearFileMetadataRequest::printTo(std::ostream& out) const {
@@ -17115,11 +16943,11 @@ void swap(CacheFileMetadataResult &a, CacheFileMetadataResult &b) {
   swap(a.isSupported, b.isSupported);
 }
 
-CacheFileMetadataResult::CacheFileMetadataResult(const CacheFileMetadataResult& other705) {
-  isSupported = other705.isSupported;
+CacheFileMetadataResult::CacheFileMetadataResult(const CacheFileMetadataResult& other701) {
+  isSupported = other701.isSupported;
 }
-CacheFileMetadataResult& CacheFileMetadataResult::operator=(const CacheFileMetadataResult& other706) {
-  isSupported = other706.isSupported;
+CacheFileMetadataResult& CacheFileMetadataResult::operator=(const CacheFileMetadataResult& other702) {
+  isSupported = other702.isSupported;
   return *this;
 }
 void CacheFileMetadataResult::printTo(std::ostream& out) const {
@@ -17260,19 +17088,19 @@ void swap(CacheFileMetadataRequest &a, CacheFileMetadataRequest &b) {
   swap(a.__isset, b.__isset);
 }
 
-CacheFileMetadataRequest::CacheFileMetadataRequest(const CacheFileMetadataRequest& other707) {
-  dbName = other707.dbName;
-  tblName = other707.tblName;
-  partName = other707.partName;
-  isAllParts = other707.isAllParts;
-  __isset = other707.__isset;
+CacheFileMetadataRequest::CacheFileMetadataRequest(const CacheFileMetadataRequest& other703) {
+  dbName = other703.dbName;
+  tblName = other703.tblName;
+  partName = other703.partName;
+  isAllParts = other703.isAllParts;
+  __isset = other703.__isset;
 }
-CacheFileMetadataRequest& CacheFileMetadataRequest::operator=(const CacheFileMetadataRequest& other708) {
-  dbName = other708.dbName;
-  tblName = other708.tblName;
-  partName = other708.partName;
-  isAllParts = other708.isAllParts;
-  __isset = other708.__isset;
+CacheFileMetadataRequest& CacheFileMetadataRequest::operator=(const CacheFileMetadataRequest& other704) {
+  dbName = other704.dbName;
+  tblName = other704.tblName;
+  partName = other704.partName;
+  isAllParts = other704.isAllParts;
+  __isset = other704.__isset;
   return *this;
 }
 void CacheFileMetadataRequest::printTo(std::ostream& out) const {
@@ -17320,14 +17148,14 @@ uint32_t GetAllFunctionsResponse::read(::apache::thrift::protocol::TProtocol* ip
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->functions.clear();
-            uint32_t _size709;
-            ::apache::thrift::protocol::TType _etype712;
-            xfer += iprot->readListBegin(_etype712, _size709);
-            this->functions.resize(_size709);
-            uint32_t _i713;
-            for (_i713 = 0; _i713 < _size709; ++_i713)
+            uint32_t _size705;
+            ::apache::thrift::protocol::TType _etype708;
+            xfer += iprot->readListBegin(_etype708, _size705);
+            this->functions.resize(_size705);
+            uint32_t _i709;
+            for (_i709 = 0; _i709 < _size705; ++_i709)
             {
-              xfer += this->functions[_i713].read(iprot);
+              xfer += this->functions[_i709].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -17357,10 +17185,10 @@ uint32_t GetAllFunctionsResponse::write(::apache::thrift::protocol::TProtocol* o
     xfer += oprot->writeFieldBegin("functions", ::apache::thrift::protocol::T_LIST, 1);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->functions.size()));
-      std::vector<Function> ::const_iterator _iter714;
-      for (_iter714 = this->functions.begin(); _iter714 != this->functions.end(); ++_iter714)
+      std::vector<Function> ::const_iterator _iter710;
+      for (_iter710 = this->functions.begin(); _iter710 != this->functions.end(); ++_iter710)
       {
-        xfer += (*_iter714).write(oprot);
+        xfer += (*_iter710).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -17377,13 +17205,13 @@ void swap(GetAllFunctionsResponse &a, GetAllFunctionsResponse &b) {
   swap(a.__isset, b.__isset);
 }
 
-GetAllFunctionsResponse::GetAllFunctionsResponse(const GetAllFunctionsResponse& other715) {
-  functions = other715.functions;
-  __isset = other715.__isset;
+GetAllFunctionsResponse::GetAllFunctionsResponse(const GetAllFunctionsResponse& other711) {
+  functions = other711.functions;
+  __isset = other711.__isset;
 }
-GetAllFunctionsResponse& GetAllFunctionsResponse::operator=(const GetAllFunctionsResponse& other716) {
-  functions = other716.functions;
-  __isset = other716.__isset;
+GetAllFunctionsResponse& GetAllFunctionsResponse::operator=(const GetAllFunctionsResponse& other712) {
+  functions = other712.functions;
+  __isset = other712.__isset;
   return *this;
 }
 void GetAllFunctionsResponse::printTo(std::ostream& out) const {
@@ -17525,19 +17353,19 @@ void swap(TableMeta &a, TableMeta &b) {
   swap(a.__isset, b.__isset);
 }
 
-TableMeta::TableMeta(const TableMeta& other717) {
-  dbName = other717.dbName;
-  tableName = other717.tableName;
-  tableType = other717.tableType;
-  comments = other717.comments;
-  __isset = other717.__isset;
+TableMeta::TableMeta(const TableMeta& other713) {
+  dbName = other713.dbName;
+  tableName = other713.tableName;
+  tableType = other713.tableType;
+  comments = other713.comments;
+  __isset = other713.__isset;
 }
-TableMeta& TableMeta::operator=(const TableMeta& other718) {
-  dbName = other718.dbName;
-  tableName = other718.tableName;
-  tableType = other718.tableType;
-  comments = other718.comments;
-  __isset = other718.__isset;
+TableMeta& TableMeta::operator=(const TableMeta& other714) {
+  dbName = other714.dbName;
+  tableName = other714.tableName;
+  tableType = other714.tableType;
+  comments = other714.comments;
+  __isset = other714.__isset;
   return *this;
 }
 void TableMeta::printTo(std::ostream& out) const {
@@ -17620,13 +17448,13 @@ void swap(MetaException &a, MetaException &b) {
   swap(a.__isset, b.__isset);
 }
 
-MetaException::MetaException(const MetaException& other719) : TException() {
-  message = other719.message;
-  __isset = other719.__isset;
+MetaException::MetaException(const MetaException& other715) : TException() {
+  message = other715.message;
+  __isset = other715.__isset;
 }
-MetaException& MetaException::operator=(const MetaException& other720) {
-  message = other720.message;
-  __isset = other720.__isset;
+MetaException& MetaException::operator=(const MetaException& other716) {
+  message = other716.message;
+  __isset = other716.__isset;
   return *this;
 }
 void MetaException::printTo(std::ostream& out) const {
@@ -17717,13 +17545,13 @@ void swap(UnknownTableException &a, UnknownTableException &b) {
   swap(a.__isset, b.__isset);
 }
 
-UnknownTableException::UnknownTableException(const UnknownTableException& other721) : TException() {
-  message = other721.message;
-  __isset = other721.__isset;
+UnknownTableException::UnknownTableException(const UnknownTableException& other717) : TException() {
+  message = other717.message;
+  __isset = other717.__isset;
 }
-UnknownTableException& UnknownTableException::operator=(const UnknownTableException& other722) {
-  message = other722.message;
-  __isset = other722.__isset;
+UnknownTableException& UnknownTableException::operator=(const UnknownTableException& other718) {
+  message = other718.message;
+  __isset = other718.__isset;
   return *this;
 }
 void UnknownTableException::printTo(std::ostream& out) const {
@@ -17814,13 +17642,13 @@ void swap(UnknownDBException &a, UnknownDBException &b) {
   swap(a.__isset, b.__isset);
 }
 
-UnknownDBException::UnknownDBException(const UnknownDBException& other723) : TException() {
-  message = other723.message;
-  __isset = other723.__isset;
+UnknownDBException::UnknownDBException(const UnknownDBException& other719) : TException() {
+  message = other719.message;
+  __isset = other719.__isset;
 }
-UnknownDBException& UnknownDBException::operator=(const UnknownDBException& other724) {
-  message = other724.message;
-  __isset = other724.__isset;
+UnknownDBException& UnknownDBException::operator=(const UnknownDBException& other720) {
+  message = other720.message;
+  __isset = other720.__isset;
   return *this;
 }
 void UnknownDBException::printTo(std::ostream& out) const {
@@ -17911,13 +17739,13 @@ void swap(AlreadyExistsException &a, AlreadyExistsException &b) {
   swap(a.__isset, b.__isset);
 }
 
-AlreadyExistsException::AlreadyExistsException(const AlreadyExistsException& other725) : TException() {
-  message = other725.message;
-  __isset = other725.__isset;
+AlreadyExistsException::AlreadyExistsException(const AlreadyExistsException& other721) : TException() {
+  message = other721.message;
+  __isset = other721.__isset;
 }
-AlreadyExistsException& AlreadyExistsException::operator=(const AlreadyExistsException& other726) {
-  message = other726.message;
-  __isset = other726.__isset;
+AlreadyExistsException& AlreadyExistsException::operator=(const AlreadyExistsException& other722) {
+  message = other722.message;
+  __isset = other722.__isset;
   return *this;
 }
 void AlreadyExistsException::printTo(std::ostream& out) const {
@@ -18008,13 +17836,13 @@ void swap(InvalidPartitionException &a, InvalidPartitionException &b) {
   swap(a.__isset, b.__isset);
 }
 
-InvalidPartitionException::InvalidPartitionException(const InvalidPartitionException& other727) : TException() {
-  message = other727.message;
-  __isset = other727.__isset;
+InvalidPartitionException::InvalidPartitionException(const InvalidPartitionException& other723) : TException() {
+  message = other723.message;
+  __isset = other723.__isset;
 }
-InvalidPartitionException& InvalidPartitionException::operator=(const InvalidPartitionException& other728) {
-  message = other728.message;
-  __isset = other728.__isset;
+InvalidPartitionException& InvalidPartitionException::operator=(const InvalidPartitionException& other724) {
+  message = other724.message;
+  __isset = other724.__isset;
   return *this;
 }
 void InvalidPartitionException::printTo(std::ostream& out) const {
@@ -18105,13 +17933,13 @@ void swap(UnknownPartitionException &a, UnknownPartitionException &b) {
   swap(a.__isset, b.__isset);
 }
 
-UnknownPartitionException::UnknownPartitionException(const UnknownPartitionException& other729) : TException() {
-  message = other729.message;
-  __isset = other729.__isset;
+UnknownPartitionException::UnknownPartitionException(const UnknownPartitionException& other725) : TException() {
+  message = other725.message;
+  __isset = other725.__isset;
 }
-UnknownPartitionException& UnknownPartitionException::operator=(const UnknownPartitionException& other730) {
-  message = other730.message;
-  __isset = other730.__isset;
+UnknownPartitionException& UnknownPartitionException::operator=(const UnknownPartitionException& other726) {
+  message = other726.message;
+  __isset = other726.__isset;
   return *this;
 }
 void UnknownPartitionException::printTo(std::ostream& out) const {
@@ -18202,13 +18030,13 @@ void swap(InvalidObjectException &a, InvalidObjectException &b) {
   swap(a.__isset, b.__isset);
 }
 
-InvalidObjectException::InvalidObjectException(const InvalidObjectException& other731) : TException() {
-  message = other731.message;
-  __isset = other731.__isset;
+InvalidObjectException::InvalidObjectException(const InvalidObjectException& other727) : TException() {
+  message = other727.message;
+  __isset = other727.__isset;
 }
-InvalidObjectException& InvalidObjectException::operator=(const InvalidObjectException& other732) {
-  message = other732.message;
-  __isset = other732.__isset;
+InvalidObjectException& InvalidObjectException::operator=(const InvalidObjectException& other728) {
+  message = other728.message;
+  __isset = other728.__isset;
   return *this;
 }
 void InvalidObjectException::printTo(std::ostream& out) const {
@@ -18299,13 +18127,13 @@ void swap(NoSuchObjectException &a, NoSuchObjectException &b) {
   swap(a.__isset, b.__isset);
 }
 
-NoSuchObjectException::NoSuchObjectException(const NoSuchObjectException& other733) : TException() {
-  message = other733.message;
-  __isset = other733.__isset;
+NoSuchObjectException::NoSuchObjectException(const NoSuchObjectException& other729) : TException() {
+  message = other729.message;
+  __isset = other729.__isset;
 }
-NoSuchObjectException& NoSuchObjectException::operator=(const NoSuchObjectException& other734) {
-  message = other734.message;
-  __isset = other734.__isset;
+NoSuchObjectException& NoSuchObjectException::operator=(const NoSuchObjectException& other730) {
+  message = other730.message;
+  __isset = other730.__isset;
   return *this;
 }
 void NoSuchObjectException::printTo(std::ostream& out) const {
@@ -18396,13 +18224,13 @@ void swap(IndexAlreadyExistsException &a, IndexAlreadyExistsException &b) {
   swap(a.__isset, b.__isset);
 }
 
-IndexAlreadyExistsException::IndexAlreadyExistsException(const IndexAlreadyExistsException& other735) : TException() {
-  message = other735.message;
-  __isset = other735.__isset;
+IndexAlreadyExistsException::IndexAlreadyExistsException(const IndexAlreadyExistsException& other731) : TException() {
+  message = other731.message;
+  __isset = other731.__isset;
 }
-IndexAlreadyExistsException& IndexAlreadyExistsException::operator=(const IndexAlreadyExistsException& other736) {
-  message = other736.message;
-  __isset = other736.__isset;
+IndexAlreadyExistsException& IndexAlreadyExistsException::operator=(const IndexAlreadyExistsException& other732) {
+  message = other732.message;
+  __isset = other732.__isset;
   return *this;
 }
 void IndexAlreadyExistsException::printTo(std::ostream& out) const {
@@ -18493,13 +18321,13 @@ void swap(InvalidOperationException &a, InvalidOperationException &b) {
   swap(a.__isset, b.__isset);
 }
 
-InvalidOperationException::InvalidOperationException(const InvalidOperationException& other737) : TException() {
-  message = other737.message;
-  __isset = other737.__isset;
+InvalidOperationException::InvalidOperationException(const InvalidOperationException& other733) : TException() {
+  message = other733.message;
+  __isset = other733.__isset;
 }
-InvalidOperationException& InvalidOperationException::operator=(const InvalidOperationException& other738) {
-  message = other738.message;
-  __isset = other738.__isset;
+InvalidOperationException& InvalidOperationException::operator=(const InvalidOperationException& other734) {
+  message = other734.message;
+  __isset = other734.__isset;
   return *this;
 }
 void InvalidOperationException::printTo(std::ostream& out) const {
@@ -18590,13 +18418,13 @@ void swap(ConfigValSecurityException &a, ConfigValSecurityException &b) {
   swap(a.__isset, b.__isset);
 }
 
-ConfigValSecurityException::ConfigValSecurityException(const ConfigValSecurityException& other739) : TException() {
-  message = other739.message;
-  __isset = other739.__isset;
+ConfigValSecurityException::ConfigValSecurityException(const ConfigValSecurityException& other735) : TException() {
+  message = other735.message;
+  __isset = other735.__isset;
 }
-ConfigValSecurityException& ConfigValSecurityException::operator=(const ConfigValSecurityException& other740) {
-  message = other740.message;
-  __isset = other740.__isset;
+ConfigValSecurityException& ConfigValSecurityException::operator=(const ConfigValSecurityException& other736) {
+  message = other736.message;
+  __isset = other736.__isset;
   return *this;
 }
 void ConfigValSecurityException::printTo(std::ostream& out) const {
@@ -18687,13 +18515,13 @@ void swap(InvalidInputException &a, InvalidInputException &b) {
   swap(a.__isset, b.__isset);
 }
 
-InvalidInputException::InvalidInputException(const InvalidInputException& other741) : TException() {
-  message = other741.message;
-  __isset = other741.__isset;
+InvalidInputException::InvalidInputException(const InvalidInputException& other737) : TException() {
+  message = other737.message;
+  __isset = other737.__isset;
 }
-InvalidInputException& InvalidInputException::operator=(const InvalidInputException& other742) {
-  message = other742.message;
-  __isset = other742.__isset;
+InvalidInputException& InvalidInputException::operator=(const InvalidInputException& other738) {
+  message = other738.message;
+  __isset = other738.__isset;
   return *this;
 }
 void InvalidInputException::printTo(std::ostream& out) const {
@@ -18784,13 +18612,13 @@ void swap(NoSuchTxnException &a, NoSuchTxnException &b) {
   swap(a.__isset, b.__isset);
 }
 
-NoSuchTxnException::NoSuchTxnException(const NoSuchTxnException& other743) : TException() {
-  message = other743.message;
-  __isset = other743.__isset;
+NoSuchTxnException::NoSuchTxnException(const NoSuchTxnException& other739) : TException() {
+  message = other739.message;
+  __isset = other739.__isset;
 }
-NoSuchTxnException& NoSuchTxnException::operator=(const NoSuchTxnException& other744) {
-  message = other744.message;
-  __isset = other744.__isset;
+NoSuchTxnException& NoSuchTxnException::operator=(const NoSuchTxnException& other740) {
+  message = other740.message;
+  __isset = other740.__isset;
   return *this;
 }
 void NoSuchTxnException::printTo(std::ostream& out) const {
@@ -18881,13 +18709,13 @@ void swap(TxnAbortedException &a, TxnAbortedException &b) {
   swap(a.__isset, b.__isset);
 }
 
-TxnAbortedException::TxnAbortedException(const TxnAbortedException& other745) : TException() {
-  message = other745.message;
-  __isset = other745.__isset;
+TxnAbortedException::TxnAbortedException(const TxnAbortedException& other741) : TException() {
+  message = other741.message;
+  __isset = other741.__isset;
 }
-TxnAbortedException& TxnAbortedException::operator=(const TxnAbortedException& other746) {
-  message = other746.message;
-  __isset = other746.__isset;
+TxnAbortedException& TxnAbortedException::operator=(const TxnAbortedException& other742) {
+  message = other742.message;
+  __isset = other742.__isset;
   return *this;
 }
 void TxnAbortedException::printTo(std::ostream& out) const {
@@ -18978,13 +18806,13 @@ void swap(TxnOpenException &a, TxnOpenException &b) {
   swap(a.__isset, b.__isset);
 }
 
-TxnOpenException::TxnOpenException(const TxnOpenException& other747) : TException() {
-  message = other747.message;
-  __isset = other747.__isset;
+TxnOpenException::TxnOpenException(const TxnOpenException& other743) : TException() {
+  message = other743.message;
+  __isset = other743.__isset;
 }
-TxnOpenException& TxnOpenException::operator=(const TxnOpenException& other748) {
-  message = other748.message;
-  __isset = other748.__isset;
+TxnOpenException& TxnOpenException::operator=(const TxnOpenException& other744) {
+  message = other744.message;
+  __isset = other744.__isset;
   return *this;
 }
 void TxnOpenException::printTo(std::ostream& out) const {
@@ -19075,13 +18903,13 @@ void swap(NoSuchLockException &a, NoSuchLockException &b) {
   swap(a.__isset, b.__isset);
 }
 
-NoSuchLockException::NoSuchLockException(const NoSuchLockException& other749) : TException() {
-  message = other749.message;
-  __isset = other749.__isset;
+NoSuchLockException::NoSuchLockException(const NoSuchLockException& other745) : TException() {
+  message = other745.message;
+  __isset = other745.__isset;
 }
-NoSuchLockException& NoSuchLockException::operator=(const NoSuchLockException& other750) {
-  message = other750.message;
-  __isset = other750.__isset;
+NoSuchLockException& NoSuchLockException::operator=(const NoSuchLockException& other746) {
+  message = other746.message;
+  __isset = other746.__isset;
   return *this;
 }
 void NoSuchLockException::printTo(std::ostream& out) const {

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
index 3b3e05e..56060f4 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
@@ -343,10 +343,6 @@ class FireEventRequest;
 
 class FireEventResponse;
 
-class GetChangeVersionRequest;
-
-class GetChangeVersionResult;
-
 class MetadataPpdResult;
 
 class GetFileMetadataByExprResult;
@@ -6420,86 +6416,6 @@ inline std::ostream& operator<<(std::ostream& out, const FireEventResponse& obj)
   return out;
 }
 
-
-class GetChangeVersionRequest {
- public:
-
-  GetChangeVersionRequest(const GetChangeVersionRequest&);
-  GetChangeVersionRequest& operator=(const GetChangeVersionRequest&);
-  GetChangeVersionRequest() : topic() {
-  }
-
-  virtual ~GetChangeVersionRequest() throw();
-  std::string topic;
-
-  void __set_topic(const std::string& val);
-
-  bool operator == (const GetChangeVersionRequest & rhs) const
-  {
-    if (!(topic == rhs.topic))
-      return false;
-    return true;
-  }
-  bool operator != (const GetChangeVersionRequest &rhs) const {
-    return !(*this == rhs);
-  }
-
-  bool operator < (const GetChangeVersionRequest & ) const;
-
-  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
-  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
-
-  virtual void printTo(std::ostream& out) const;
-};
-
-void swap(GetChangeVersionRequest &a, GetChangeVersionRequest &b);
-
-inline std::ostream& operator<<(std::ostream& out, const GetChangeVersionRequest& obj)
-{
-  obj.printTo(out);
-  return out;
-}
-
-
-class GetChangeVersionResult {
- public:
-
-  GetChangeVersionResult(const GetChangeVersionResult&);
-  GetChangeVersionResult& operator=(const GetChangeVersionResult&);
-  GetChangeVersionResult() : version(0) {
-  }
-
-  virtual ~GetChangeVersionResult() throw();
-  int64_t version;
-
-  void __set_version(const int64_t val);
-
-  bool operator == (const GetChangeVersionResult & rhs) const
-  {
-    if (!(version == rhs.version))
-      return false;
-    return true;
-  }
-  bool operator != (const GetChangeVersionResult &rhs) const {
-    return !(*this == rhs);
-  }
-
-  bool operator < (const GetChangeVersionResult & ) const;
-
-  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
-  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
-
-  virtual void printTo(std::ostream& out) const;
-};
-
-void swap(GetChangeVersionResult &a, GetChangeVersionResult &b);
-
-inline std::ostream& operator<<(std::ostream& out, const GetChangeVersionResult& obj)
-{
-  obj.printTo(out);
-  return out;
-}
-
 typedef struct _MetadataPpdResult__isset {
   _MetadataPpdResult__isset() : metadata(false), includeBitset(false) {}
   bool metadata :1;

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionRequest.java
deleted file mode 100644
index a410331..0000000
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionRequest.java
+++ /dev/null
@@ -1,389 +0,0 @@
-/**
- * Autogenerated by Thrift Compiler (0.9.3)
- *
- * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
- *  @generated
- */
-package org.apache.hadoop.hive.metastore.api;
-
-import org.apache.thrift.scheme.IScheme;
-import org.apache.thrift.scheme.SchemeFactory;
-import org.apache.thrift.scheme.StandardScheme;
-
-import org.apache.thrift.scheme.TupleScheme;
-import org.apache.thrift.protocol.TTupleProtocol;
-import org.apache.thrift.protocol.TProtocolException;
-import org.apache.thrift.EncodingUtils;
-import org.apache.thrift.TException;
-import org.apache.thrift.async.AsyncMethodCallback;
-import org.apache.thrift.server.AbstractNonblockingServer.*;
-import java.util.List;
-import java.util.ArrayList;
-import java.util.Map;
-import java.util.HashMap;
-import java.util.EnumMap;
-import java.util.Set;
-import java.util.HashSet;
-import java.util.EnumSet;
-import java.util.Collections;
-import java.util.BitSet;
-import java.nio.ByteBuffer;
-import java.util.Arrays;
-import javax.annotation.Generated;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
-@Generated(value = "Autogenerated by Thrift Compiler (0.9.3)")
-public class GetChangeVersionRequest implements org.apache.thrift.TBase<GetChangeVersionRequest, GetChangeVersionRequest._Fields>, java.io.Serializable, Cloneable, Comparable<GetChangeVersionRequest> {
-  private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetChangeVersionRequest");
-
-  private static final org.apache.thrift.protocol.TField TOPIC_FIELD_DESC = new org.apache.thrift.protocol.TField("topic", org.apache.thrift.protocol.TType.STRING, (short)1);
-
-  private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
-  static {
-    schemes.put(StandardScheme.class, new GetChangeVersionRequestStandardSchemeFactory());
-    schemes.put(TupleScheme.class, new GetChangeVersionRequestTupleSchemeFactory());
-  }
-
-  private String topic; // required
-
-  /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
-    TOPIC((short)1, "topic");
-
-    private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
-
-    static {
-      for (_Fields field : EnumSet.allOf(_Fields.class)) {
-        byName.put(field.getFieldName(), field);
-      }
-    }
-
-    /**
-     * Find the _Fields constant that matches fieldId, or null if its not found.
-     */
-    public static _Fields findByThriftId(int fieldId) {
-      switch(fieldId) {
-        case 1: // TOPIC
-          return TOPIC;
-        default:
-          return null;
-      }
-    }
-
-    /**
-     * Find the _Fields constant that matches fieldId, throwing an exception
-     * if it is not found.
-     */
-    public static _Fields findByThriftIdOrThrow(int fieldId) {
-      _Fields fields = findByThriftId(fieldId);
-      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
-      return fields;
-    }
-
-    /**
-     * Find the _Fields constant that matches name, or null if its not found.
-     */
-    public static _Fields findByName(String name) {
-      return byName.get(name);
-    }
-
-    private final short _thriftId;
-    private final String _fieldName;
-
-    _Fields(short thriftId, String fieldName) {
-      _thriftId = thriftId;
-      _fieldName = fieldName;
-    }
-
-    public short getThriftFieldId() {
-      return _thriftId;
-    }
-
-    public String getFieldName() {
-      return _fieldName;
-    }
-  }
-
-  // isset id assignments
-  public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
-  static {
-    Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
-    tmpMap.put(_Fields.TOPIC, new org.apache.thrift.meta_data.FieldMetaData("topic", org.apache.thrift.TFieldRequirementType.REQUIRED, 
-        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
-    metaDataMap = Collections.unmodifiableMap(tmpMap);
-    org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(GetChangeVersionRequest.class, metaDataMap);
-  }
-
-  public GetChangeVersionRequest() {
-  }
-
-  public GetChangeVersionRequest(
-    String topic)
-  {
-    this();
-    this.topic = topic;
-  }
-
-  /**
-   * Performs a deep copy on <i>other</i>.
-   */
-  public GetChangeVersionRequest(GetChangeVersionRequest other) {
-    if (other.isSetTopic()) {
-      this.topic = other.topic;
-    }
-  }
-
-  public GetChangeVersionRequest deepCopy() {
-    return new GetChangeVersionRequest(this);
-  }
-
-  @Override
-  public void clear() {
-    this.topic = null;
-  }
-
-  public String getTopic() {
-    return this.topic;
-  }
-
-  public void setTopic(String topic) {
-    this.topic = topic;
-  }
-
-  public void unsetTopic() {
-    this.topic = null;
-  }
-
-  /** Returns true if field topic is set (has been assigned a value) and false otherwise */
-  public boolean isSetTopic() {
-    return this.topic != null;
-  }
-
-  public void setTopicIsSet(boolean value) {
-    if (!value) {
-      this.topic = null;
-    }
-  }
-
-  public void setFieldValue(_Fields field, Object value) {
-    switch (field) {
-    case TOPIC:
-      if (value == null) {
-        unsetTopic();
-      } else {
-        setTopic((String)value);
-      }
-      break;
-
-    }
-  }
-
-  public Object getFieldValue(_Fields field) {
-    switch (field) {
-    case TOPIC:
-      return getTopic();
-
-    }
-    throw new IllegalStateException();
-  }
-
-  /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
-  public boolean isSet(_Fields field) {
-    if (field == null) {
-      throw new IllegalArgumentException();
-    }
-
-    switch (field) {
-    case TOPIC:
-      return isSetTopic();
-    }
-    throw new IllegalStateException();
-  }
-
-  @Override
-  public boolean equals(Object that) {
-    if (that == null)
-      return false;
-    if (that instanceof GetChangeVersionRequest)
-      return this.equals((GetChangeVersionRequest)that);
-    return false;
-  }
-
-  public boolean equals(GetChangeVersionRequest that) {
-    if (that == null)
-      return false;
-
-    boolean this_present_topic = true && this.isSetTopic();
-    boolean that_present_topic = true && that.isSetTopic();
-    if (this_present_topic || that_present_topic) {
-      if (!(this_present_topic && that_present_topic))
-        return false;
-      if (!this.topic.equals(that.topic))
-        return false;
-    }
-
-    return true;
-  }
-
-  @Override
-  public int hashCode() {
-    List<Object> list = new ArrayList<Object>();
-
-    boolean present_topic = true && (isSetTopic());
-    list.add(present_topic);
-    if (present_topic)
-      list.add(topic);
-
-    return list.hashCode();
-  }
-
-  @Override
-  public int compareTo(GetChangeVersionRequest other) {
-    if (!getClass().equals(other.getClass())) {
-      return getClass().getName().compareTo(other.getClass().getName());
-    }
-
-    int lastComparison = 0;
-
-    lastComparison = Boolean.valueOf(isSetTopic()).compareTo(other.isSetTopic());
-    if (lastComparison != 0) {
-      return lastComparison;
-    }
-    if (isSetTopic()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.topic, other.topic);
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-    }
-    return 0;
-  }
-
-  public _Fields fieldForId(int fieldId) {
-    return _Fields.findByThriftId(fieldId);
-  }
-
-  public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
-    schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
-  }
-
-  public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
-    schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
-  }
-
-  @Override
-  public String toString() {
-    StringBuilder sb = new StringBuilder("GetChangeVersionRequest(");
-    boolean first = true;
-
-    sb.append("topic:");
-    if (this.topic == null) {
-      sb.append("null");
-    } else {
-      sb.append(this.topic);
-    }
-    first = false;
-    sb.append(")");
-    return sb.toString();
-  }
-
-  public void validate() throws org.apache.thrift.TException {
-    // check for required fields
-    if (!isSetTopic()) {
-      throw new org.apache.thrift.protocol.TProtocolException("Required field 'topic' is unset! Struct:" + toString());
-    }
-
-    // check for sub-struct validity
-  }
-
-  private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
-    try {
-      write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
-    } catch (org.apache.thrift.TException te) {
-      throw new java.io.IOException(te);
-    }
-  }
-
-  private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
-    try {
-      read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
-    } catch (org.apache.thrift.TException te) {
-      throw new java.io.IOException(te);
-    }
-  }
-
-  private static class GetChangeVersionRequestStandardSchemeFactory implements SchemeFactory {
-    public GetChangeVersionRequestStandardScheme getScheme() {
-      return new GetChangeVersionRequestStandardScheme();
-    }
-  }
-
-  private static class GetChangeVersionRequestStandardScheme extends StandardScheme<GetChangeVersionRequest> {
-
-    public void read(org.apache.thrift.protocol.TProtocol iprot, GetChangeVersionRequest struct) throws org.apache.thrift.TException {
-      org.apache.thrift.protocol.TField schemeField;
-      iprot.readStructBegin();
-      while (true)
-      {
-        schemeField = iprot.readFieldBegin();
-        if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
-          break;
-        }
-        switch (schemeField.id) {
-          case 1: // TOPIC
-            if (schemeField.type == org.apache.thrift.protocol.TType.STRING) {
-              struct.topic = iprot.readString();
-              struct.setTopicIsSet(true);
-            } else { 
-              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-            }
-            break;
-          default:
-            org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-        }
-        iprot.readFieldEnd();
-      }
-      iprot.readStructEnd();
-      struct.validate();
-    }
-
-    public void write(org.apache.thrift.protocol.TProtocol oprot, GetChangeVersionRequest struct) throws org.apache.thrift.TException {
-      struct.validate();
-
-      oprot.writeStructBegin(STRUCT_DESC);
-      if (struct.topic != null) {
-        oprot.writeFieldBegin(TOPIC_FIELD_DESC);
-        oprot.writeString(struct.topic);
-        oprot.writeFieldEnd();
-      }
-      oprot.writeFieldStop();
-      oprot.writeStructEnd();
-    }
-
-  }
-
-  private static class GetChangeVersionRequestTupleSchemeFactory implements SchemeFactory {
-    public GetChangeVersionRequestTupleScheme getScheme() {
-      return new GetChangeVersionRequestTupleScheme();
-    }
-  }
-
-  private static class GetChangeVersionRequestTupleScheme extends TupleScheme<GetChangeVersionRequest> {
-
-    @Override
-    public void write(org.apache.thrift.protocol.TProtocol prot, GetChangeVersionRequest struct) throws org.apache.thrift.TException {
-      TTupleProtocol oprot = (TTupleProtocol) prot;
-      oprot.writeString(struct.topic);
-    }
-
-    @Override
-    public void read(org.apache.thrift.protocol.TProtocol prot, GetChangeVersionRequest struct) throws org.apache.thrift.TException {
-      TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.topic = iprot.readString();
-      struct.setTopicIsSet(true);
-    }
-  }
-
-}
-

http://git-wip-us.apache.org/repos/asf/hive/blob/10c07d6e/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionResult.java
deleted file mode 100644
index 7a2f74c..0000000
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetChangeVersionResult.java
+++ /dev/null
@@ -1,387 +0,0 @@
-/**
- * Autogenerated by Thrift Compiler (0.9.3)
- *
- * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
- *  @generated
- */
-package org.apache.hadoop.hive.metastore.api;
-
-import org.apache.thrift.scheme.IScheme;
-import org.apache.thrift.scheme.SchemeFactory;
-import org.apache.thrift.scheme.StandardScheme;
-
-import org.apache.thrift.scheme.TupleScheme;
-import org.apache.thrift.protocol.TTupleProtocol;
-import org.apache.thrift.protocol.TProtocolException;
-import org.apache.thrift.EncodingUtils;
-import org.apache.thrift.TException;
-import org.apache.thrift.async.AsyncMethodCallback;
-import org.apache.thrift.server.AbstractNonblockingServer.*;
-import java.util.List;
-import java.util.ArrayList;
-import java.util.Map;
-import java.util.HashMap;
-import java.util.EnumMap;
-import java.util.Set;
-import java.util.HashSet;
-import java.util.EnumSet;
-import java.util.Collections;
-import java.util.BitSet;
-import java.nio.ByteBuffer;
-import java.util.Arrays;
-import javax.annotation.Generated;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
-@Generated(value = "Autogenerated by Thrift Compiler (0.9.3)")
-public class GetChangeVersionResult implements org.apache.thrift.TBase<GetChangeVersionResult, GetChangeVersionResult._Fields>, java.io.Serializable, Cloneable, Comparable<GetChangeVersionResult> {
-  private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetChangeVersionResult");
-
-  private static final org.apache.thrift.protocol.TField VERSION_FIELD_DESC = new org.apache.thrift.protocol.TField("version", org.apache.thrift.protocol.TType.I64, (short)1);
-
-  private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
-  static {
-    schemes.put(StandardScheme.class, new GetChangeVersionResultStandardSchemeFactory());
-    schemes.put(TupleScheme.class, new GetChangeVersionResultTupleSchemeFactory());
-  }
-
-  private long version; // required
-
-  /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
-    VERSION((short)1, "version");
-
-    private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
-
-    static {
-      for (_Fields field : EnumSet.allOf(_Fields.class)) {
-        byName.put(field.getFieldName(), field);
-      }
-    }
-
-    /**
-     * Find the _Fields constant that matches fieldId, or null if its not found.
-     */
-    public static _Fields findByThriftId(int fieldId) {
-      switch(fieldId) {
-        case 1: // VERSION
-          return VERSION;
-        default:
-          return null;
-      }
-    }
-
-    /**
-     * Find the _Fields constant that matches fieldId, throwing an exception
-     * if it is not found.
-     */
-    public static _Fields findByThriftIdOrThrow(int fieldId) {
-      _Fields fields = findByThriftId(fieldId);
-      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
-      return fields;
-    }
-
-    /**
-     * Find the _Fields constant that matches name, or null if its not found.
-     */
-    public static _Fields findByName(String name) {
-      return byName.get(name);
-    }
-
-    private final short _thriftId;
-    private final String _fieldName;
-
-    _Fields(short thriftId, String fieldName) {
-      _thriftId = thriftId;
-      _fieldName = fieldName;
-    }
-
-    public short getThriftFieldId() {
-      return _thriftId;
-    }
-
-    public String getFieldName() {
-      return _fieldName;
-    }
-  }
-
-  // isset id assignments
-  private static final int __VERSION_ISSET_ID = 0;
-  private byte __isset_bitfield = 0;
-  public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
-  static {
-    Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
-    tmpMap.put(_Fields.VERSION, new org.apache.thrift.meta_data.FieldMetaData("version", org.apache.thrift.TFieldRequirementType.REQUIRED, 
-        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64)));
-    metaDataMap = Collections.unmodifiableMap(tmpMap);
-    org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(GetChangeVersionResult.class, metaDataMap);
-  }
-
-  public GetChangeVersionResult() {
-  }
-
-  public GetChangeVersionResult(
-    long version)
-  {
-    this();
-    this.version = version;
-    setVersionIsSet(true);
-  }
-
-  /**
-   * Performs a deep copy on <i>other</i>.
-   */
-  public GetChangeVersionResult(GetChangeVersionResult other) {
-    __isset_bitfield = other.__isset_bitfield;
-    this.version = other.version;
-  }
-
-  public GetChangeVersionResult deepCopy() {
-    return new GetChangeVersionResult(this);
-  }
-
-  @Override
-  public void clear() {
-    setVersionIsSet(false);
-    this.version = 0;
-  }
-
-  public long getVersion() {
-    return this.version;
-  }
-
-  public void setVersion(long version) {
-    this.version = version;
-    setVersionIsSet(true);
-  }
-
-  public void unsetVersion() {
-    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __VERSION_ISSET_ID);
-  }
-
-  /** Returns true if field version is set (has been assigned a value) and false otherwise */
-  public boolean isSetVersion() {
-    return EncodingUtils.testBit(__isset_bitfield, __VERSION_ISSET_ID);
-  }
-
-  public void setVersionIsSet(boolean value) {
-    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __VERSION_ISSET_ID, value);
-  }
-
-  public void setFieldValue(_Fields field, Object value) {
-    switch (field) {
-    case VERSION:
-      if (value == null) {
-        unsetVersion();
-      } else {
-        setVersion((Long)value);
-      }
-      break;
-
-    }
-  }
-
-  public Object getFieldValue(_Fields field) {
-    switch (field) {
-    case VERSION:
-      return getVersion();
-
-    }
-    throw new IllegalStateException();
-  }
-
-  /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
-  public boolean isSet(_Fields field) {
-    if (field == null) {
-      throw new IllegalArgumentException();
-    }
-
-    switch (field) {
-    case VERSION:
-      return isSetVersion();
-    }
-    throw new IllegalStateException();
-  }
-
-  @Override
-  public boolean equals(Object that) {
-    if (that == null)
-      return false;
-    if (that instanceof GetChangeVersionResult)
-      return this.equals((GetChangeVersionResult)that);
-    return false;
-  }
-
-  public boolean equals(GetChangeVersionResult that) {
-    if (that == null)
-      return false;
-
-    boolean this_present_version = true;
-    boolean that_present_version = true;
-    if (this_present_version || that_present_version) {
-      if (!(this_present_version && that_present_version))
-        return false;
-      if (this.version != that.version)
-        return false;
-    }
-
-    return true;
-  }
-
-  @Override
-  public int hashCode() {
-    List<Object> list = new ArrayList<Object>();
-
-    boolean present_version = true;
-    list.add(present_version);
-    if (present_version)
-      list.add(version);
-
-    return list.hashCode();
-  }
-
-  @Override
-  public int compareTo(GetChangeVersionResult other) {
-    if (!getClass().equals(other.getClass())) {
-      return getClass().getName().compareTo(other.getClass().getName());
-    }
-
-    int lastComparison = 0;
-
-    lastComparison = Boolean.valueOf(isSetVersion()).compareTo(other.isSetVersion());
-    if (lastComparison != 0) {
-      return lastComparison;
-    }
-    if (isSetVersion()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.version, other.version);
-      if (lastComparison != 0) {
-        return lastComparison;
-      }
-    }
-    return 0;
-  }
-
-  public _Fields fieldForId(int fieldId) {
-    return _Fields.findByThriftId(fieldId);
-  }
-
-  public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
-    schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
-  }
-
-  public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
-    schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
-  }
-
-  @Override
-  public String toString() {
-    StringBuilder sb = new StringBuilder("GetChangeVersionResult(");
-    boolean first = true;
-
-    sb.append("version:");
-    sb.append(this.version);
-    first = false;
-    sb.append(")");
-    return sb.toString();
-  }
-
-  public void validate() throws org.apache.thrift.TException {
-    // check for required fields
-    if (!isSetVersion()) {
-      throw new org.apache.thrift.protocol.TProtocolException("Required field 'version' is unset! Struct:" + toString());
-    }
-
-    // check for sub-struct validity
-  }
-
-  private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
-    try {
-      write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
-    } catch (org.apache.thrift.TException te) {
-      throw new java.io.IOException(te);
-    }
-  }
-
-  private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
-    try {
-      // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
-      __isset_bitfield = 0;
-      read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
-    } catch (org.apache.thrift.TException te) {
-      throw new java.io.IOException(te);
-    }
-  }
-
-  private static class GetChangeVersionResultStandardSchemeFactory implements SchemeFactory {
-    public GetChangeVersionResultStandardScheme getScheme() {
-      return new GetChangeVersionResultStandardScheme();
-    }
-  }
-
-  private static class GetChangeVersionResultStandardScheme extends StandardScheme<GetChangeVersionResult> {
-
-    public void read(org.apache.thrift.protocol.TProtocol iprot, GetChangeVersionResult struct) throws org.apache.thrift.TException {
-      org.apache.thrift.protocol.TField schemeField;
-      iprot.readStructBegin();
-      while (true)
-      {
-        schemeField = iprot.readFieldBegin();
-        if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
-          break;
-        }
-        switch (schemeField.id) {
-          case 1: // VERSION
-            if (schemeField.type == org.apache.thrift.protocol.TType.I64) {
-              struct.version = iprot.readI64();
-              struct.setVersionIsSet(true);
-            } else { 
-              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-            }
-            break;
-          default:
-            org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
-        }
-        iprot.readFieldEnd();
-      }
-      iprot.readStructEnd();
-      struct.validate();
-    }
-
-    public void write(org.apache.thrift.protocol.TProtocol oprot, GetChangeVersionResult struct) throws org.apache.thrift.TException {
-      struct.validate();
-
-      oprot.writeStructBegin(STRUCT_DESC);
-      oprot.writeFieldBegin(VERSION_FIELD_DESC);
-      oprot.writeI64(struct.version);
-      oprot.writeFieldEnd();
-      oprot.writeFieldStop();
-      oprot.writeStructEnd();
-    }
-
-  }
-
-  private static class GetChangeVersionResultTupleSchemeFactory implements SchemeFactory {
-    public GetChangeVersionResultTupleScheme getScheme() {
-      return new GetChangeVersionResultTupleScheme();
-    }
-  }
-
-  private static class GetChangeVersionResultTupleScheme extends TupleScheme<GetChangeVersionResult> {
-
-    @Override
-    public void write(org.apache.thrift.protocol.TProtocol prot, GetChangeVersionResult struct) throws org.apache.thrift.TException {
-      TTupleProtocol oprot = (TTupleProtocol) prot;
-      oprot.writeI64(struct.version);
-    }
-
-    @Override
-    public void read(org.apache.thrift.protocol.TProtocol prot, GetChangeVersionResult struct) throws org.apache.thrift.TException {
-      TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.version = iprot.readI64();
-      struct.setVersionIsSet(true);
-    }
-  }
-
-}
-