You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafodion.apache.org by db...@apache.org on 2016/02/04 19:34:58 UTC

[3/4] incubator-trafodion git commit: [JIRA-1750] remove qpid dependency

[JIRA-1750] remove qpid dependency


Project: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/commit/852e01a7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/tree/852e01a7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-trafodion/diff/852e01a7

Branch: refs/heads/master
Commit: 852e01a73044017be0c743126e4923e9d04d1806
Parents: 4f8bbf7
Author: Liu Ming <mi...@esgyn.cn>
Authored: Wed Feb 3 13:29:44 2016 +0000
Committer: Liu Ming <mi...@esgyn.cn>
Committed: Wed Feb 3 13:29:44 2016 +0000

----------------------------------------------------------------------
 core/sqf/monitor/linux/amqpmon.cxx     |  231 --
 core/sqf/monitor/linux/amqpmon.h       |   71 -
 core/sqf/src/tm/dtm.events.pb.cc       | 1185 --------
 core/sqf/src/tm/dtm.events.pb.h        |  709 -----
 core/sqf/src/tm/dtm.perf_stats.pb.cc   | 4081 ---------------------------
 core/sqf/src/tm/dtm.perf_stats.pb.h    | 2442 ----------------
 core/sql/sqlmxevents/logmxevent_sq.cpp |    2 +-
 7 files changed, 1 insertion(+), 8720 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/852e01a7/core/sqf/monitor/linux/amqpmon.cxx
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/amqpmon.cxx b/core/sqf/monitor/linux/amqpmon.cxx
deleted file mode 100644
index e680e57..0000000
--- a/core/sqf/monitor/linux/amqpmon.cxx
+++ /dev/null
@@ -1,231 +0,0 @@
-///////////////////////////////////////////////////////////////////////////////
-//
-// @@@ START COPYRIGHT @@@
-//
-// 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.
-//
-// @@@ END COPYRIGHT @@@
-//
-///////////////////////////////////////////////////////////////////////////////
-
-#ifdef USE_SEAPILOT
-#include "amqpmon.h"
-#include "wrapper/amqpwrapper.h"
-
-bool amqp_initialized = false;
-#endif
-
-#include "msgdef.h"
-
-void AMQP_INITIALIZE()
-{
-#ifdef USE_SEAPILOT
-
-    if (!amqp_initialized)
-        createAMQPConnection();
-#endif
-}
-void STARTUP ()
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    monitor::instance_up mon_instance;
-    initAMQPInfoHeader(mon_instance.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "instance_up");
-    sendAMQPMessage(false, mon_instance.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void SHUTDOWN (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::instance_down mon_instance;
-
-    mon_instance.set_nid(local_msg->u.request.u.shutdown.nid);
-    mon_instance.set_pid(local_msg->u.request.u.shutdown.pid);
-    mon_instance.set_level(local_msg->u.request.u.shutdown.level);
-
-    initAMQPInfoHeader(mon_instance.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "mon_instance");
-    sendAMQPMessage(false, mon_instance.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void NODEDOWN (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::node_down node_down;
-
-    node_down.set_nid(local_msg->u.request.u.down.nid);
-    node_down.set_node_name(local_msg->u.request.u.down.node_name);
-
-    initAMQPInfoHeader(node_down.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "node_down");
-    sendAMQPMessage(false, node_down.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void NODEUP (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::node_up node_up;
-
-    node_up.set_nid(local_msg->u.request.u.up.nid);
-    node_up.set_node_name(local_msg->u.request.u.up.node_name);
-
-    initAMQPInfoHeader(node_up.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "node_up");
-    sendAMQPMessage(false, node_up.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-void PROCESSOPEN (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::process_open process_open;
-
-    process_open.set_nid(local_msg->u.request.u.open.nid);
-    process_open.set_pid(local_msg->u.request.u.open.pid);
-    process_open.set_process_name(local_msg->u.request.u.open.process_name);
-    process_open.set_death_notification(local_msg->u.request.u.open.death_notification);
-
-    initAMQPInfoHeader(process_open.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "process_open");
-    sendAMQPMessage(false, process_open.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void PROCESSCLOSE (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::process_close process_close;
-
-    process_close.set_nid(local_msg->u.request.u.close.nid);
-    process_close.set_pid(local_msg->u.request.u.close.pid);
-    process_close.set_process_name(local_msg->u.request.u.close.process_name);
-    process_close.set_aborted(local_msg->u.request.u.close.aborted);
-    process_close.set_mon(local_msg->u.request.u.close.mon);
-
-    initAMQPInfoHeader(process_close.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "process_close");
-    sendAMQPMessage(false, process_close.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void PROCESSSTART (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::process_start process_start;
-
-    process_start.set_nid(local_msg->u.request.u.startup.nid);
-    process_start.set_nid(local_msg->u.request.u.startup.pid);
-    process_start.set_os_pid(local_msg->u.request.u.startup.os_pid);
-    process_start.set_system_messages(local_msg->u.request.u.startup.system_messages);
-    process_start.set_port_name(local_msg->u.request.u.startup.port_name);
-    process_start.set_paired(local_msg->u.request.u.startup.paired);
-    process_start.set_program(local_msg->u.request.u.startup.program);
-    process_start.set_process_name(local_msg->u.request.u.startup.process_name);
-
-    initAMQPInfoHeader(process_start.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "process_start");
-    sendAMQPMessage(false, process_start.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void PROCESSKILL (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::process_kill process_kill;
-
-    process_kill.set_nid(local_msg->u.request.u.kill.nid);
-    process_kill.set_pid(local_msg->u.request.u.kill.pid);
-    process_kill.set_target_nid(local_msg->u.request.u.kill.target_nid);
-    process_kill.set_target_pid(local_msg->u.request.u.kill.target_pid);
-    process_kill.set_process_name(local_msg->u.request.u.kill.process_name);
-
-    initAMQPInfoHeader(process_kill.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "process_kill");
-    sendAMQPMessage(false, process_kill.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-
-void PROCESSEXIT (void *msg)
-{
-#ifdef USE_SEAPILOT
-    if (!amqp_initialized)
-        AMQP_INITIALIZE();
-
-    struct message_def *local_msg = (struct message_def *)msg;
-    monitor::process_exit process_exit;
-
-    process_exit.set_nid(local_msg->u.request.u.exit.nid);
-    process_exit.set_pid(local_msg->u.request.u.exit.pid);
-
-    initAMQPInfoHeader(process_exit.mutable_header(), 1);
-    AMQPRoutingKey routingKey(SP_HEALTH_STATE, SP_MONITORPACKAGE, SP_INSTANCE, 
-                              SP_PUBLIC, SP_GPBPROTOCOL, "process_exit");
-    sendAMQPMessage(false, process_exit.SerializeAsString(), 
-                    SP_CONTENT_TYPE_APP, routingKey);
-#endif
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/852e01a7/core/sqf/monitor/linux/amqpmon.h
----------------------------------------------------------------------
diff --git a/core/sqf/monitor/linux/amqpmon.h b/core/sqf/monitor/linux/amqpmon.h
deleted file mode 100644
index 75042ef..0000000
--- a/core/sqf/monitor/linux/amqpmon.h
+++ /dev/null
@@ -1,71 +0,0 @@
-///////////////////////////////////////////////////////////////////////////////
-//
-// @@@ START COPYRIGHT @@@
-//
-// 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.
-//
-// @@@ END COPYRIGHT @@@
-//
-///////////////////////////////////////////////////////////////////////////////
-
-#ifdef USE_SEAPILOT
-#include <qpid/messaging/Connection.h>
-#include <qpid/messaging/Session.h>
-#include <qpid/messaging/Message.h>
-#include <qpid/messaging/Address.h>
-#include <qpid/messaging/Sender.h>
-#include <qpid/messaging/Receiver.h>
-#include <qpid/types/Variant.h>
-
-#include  "common/monitor.instance_down.pb.h"
-#include  "common/monitor.instance_up.pb.h"
-#include  "common/monitor.node_down.pb.h"
-#include  "common/monitor.node_up.pb.h"
-#include  "common/monitor.process_close.pb.h"
-#include  "common/monitor.process_exit.pb.h"
-#include  "common/monitor.process_kill.pb.h"
-#include  "common/monitor.process_open.pb.h"
-#include  "common/monitor.process_start.pb.h"
-
-
-#include <cstdlib>
-#include <ctime>
-#include <cstdio>
-#include <iostream>
-#include <sstream>
-
-using namespace qpid;
-
-using std::stringstream;
-using std::string;
-
-extern bool amqp_initialized;
-#endif
-
-void AMQP_INITIALIZE();
-void NODEUP (void *msg);
-void NODEDOWN (void *msg);
-void PROCESSCLOSE (void *msg);
-void PROCESSEXIT (void *msg);
-void PROCESSKILL (void *msg);
-void PROCESSOPEN (void *msg);
-void PROCESSSTART (void *msg);
-void STARTUP ();
-void SHUTDOWN (void *msg);
-
-

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/852e01a7/core/sqf/src/tm/dtm.events.pb.cc
----------------------------------------------------------------------
diff --git a/core/sqf/src/tm/dtm.events.pb.cc b/core/sqf/src/tm/dtm.events.pb.cc
deleted file mode 100644
index 377e43c..0000000
--- a/core/sqf/src/tm/dtm.events.pb.cc
+++ /dev/null
@@ -1,1185 +0,0 @@
-// Generated by the protocol buffer compiler.  DO NOT EDIT!
-
-#include "dtm.events.pb.h"
-#include <google/protobuf/stubs/once.h>
-#include <google/protobuf/descriptor.h>
-#include <google/protobuf/io/coded_stream.h>
-#include <google/protobuf/reflection_ops.h>
-#include <google/protobuf/wire_format_inl.h>
-
-namespace dtm {
-
-namespace {
-
-const ::google::protobuf::Descriptor* events_descriptor_ = NULL;
-const ::google::protobuf::internal::GeneratedMessageReflection*
-  events_reflection_ = NULL;
-
-}  // namespace
-
-
-void protobuf_AssignDesc_dtm_2eevents_2eproto() {
-  protobuf_AddDesc_dtm_2eevents_2eproto();
-  const ::google::protobuf::FileDescriptor* file =
-    ::google::protobuf::DescriptorPool::generated_pool()->FindFileByName(
-      "dtm.events.proto");
-  GOOGLE_CHECK(file != NULL);
-  events_descriptor_ = file->message_type(0);
-  static const int events_offsets_[23] = {
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, header_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, error_code_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, rmid_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, dtmid_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, seq_num_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, msgid_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, xa_error_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, pool_size_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, pool_elems_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, msg_retries_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, pool_high_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, pool_low_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, pool_max_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, tx_state_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, data_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, data1_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, data2_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, string1_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, node_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, msgid2_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, offset_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, tm_event_msg_),
-    GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, data4_),
-  };
-  events_reflection_ =
-    new ::google::protobuf::internal::GeneratedMessageReflection(
-      events_descriptor_,
-      events::default_instance_,
-      events_offsets_,
-      GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, _has_bits_[0]),
-      GOOGLE_PROTOBUF_GENERATED_MESSAGE_FIELD_OFFSET(events, _unknown_fields_),
-      -1,
-      ::google::protobuf::DescriptorPool::generated_pool(),
-      ::google::protobuf::MessageFactory::generated_factory(),
-      sizeof(events));
-}
-
-namespace {
-
-GOOGLE_PROTOBUF_DECLARE_ONCE(protobuf_AssignDescriptors_once_);
-inline void protobuf_AssignDescriptorsOnce() {
-  ::google::protobuf::GoogleOnceInit(&protobuf_AssignDescriptors_once_,
-                 &protobuf_AssignDesc_dtm_2eevents_2eproto);
-}
-
-void protobuf_RegisterTypes() {
-  protobuf_AssignDescriptorsOnce();
-  ::google::protobuf::MessageFactory::InternalRegisterGeneratedMessage(
-    events_descriptor_, &events::default_instance());
-}
-
-}  // namespace
-
-void protobuf_ShutdownFile_dtm_2eevents_2eproto() {
-  delete events::default_instance_;
-  delete events_reflection_;
-}
-
-void protobuf_AddDesc_dtm_2eevents_2eproto() {
-  static bool already_here = false;
-  if (already_here) return;
-  already_here = true;
-  GOOGLE_PROTOBUF_VERIFY_VERSION;
-
-  ::common::protobuf_AddDesc_common_2eevent_5fheader_2eproto();
-  ::google::protobuf::DescriptorPool::InternalAddGeneratedFile(
-    "\n\020dtm.events.proto\022\003dtm\032\031common.event_he"
-    "ader.proto\"\246\003\n\006events\022$\n\006header\030\001 \002(\0132\024."
-    "common.event_header\022\022\n\nerror_code\030\002 \001(\005\022"
-    "\014\n\004rmid\030\003 \001(\005\022\r\n\005dtmid\030\004 \001(\005\022\017\n\007seq_num\030"
-    "\005 \001(\005\022\r\n\005msgid\030\006 \001(\005\022\020\n\010xa_error\030\007 \001(\003\022\021"
-    "\n\tpool_size\030\010 \001(\005\022\022\n\npool_elems\030\t \001(\005\022\023\n"
-    "\013msg_retries\030\n \001(\005\022\021\n\tpool_high\030\013 \001(\005\022\020\n"
-    "\010pool_low\030\014 \001(\005\022\020\n\010pool_max\030\r \001(\005\022\020\n\010tx_"
-    "state\030\016 \001(\005\022\014\n\004data\030\017 \001(\005\022\r\n\005data1\030\020 \001(\005"
-    "\022\r\n\005data2\030\021 \001(\003\022\017\n\007string1\030\022 \001(\t\022\014\n\004node"
-    "\030\023 \001(\005\022\016\n\006msgid2\030\024 \001(\005\022\016\n\006offset\030\025 \001(\005\022\024"
-    "\n\014tm_event_msg\030\026 \001(\005\022\r\n\005data4\030\027 \001(\r", 475);
-  ::google::protobuf::MessageFactory::InternalRegisterGeneratedFile(
-    "dtm.events.proto", &protobuf_RegisterTypes);
-  events::default_instance_ = new events();
-  events::default_instance_->InitAsDefaultInstance();
-  ::google::protobuf::internal::OnShutdown(&protobuf_ShutdownFile_dtm_2eevents_2eproto);
-}
-
-// Force AddDescriptors() to be called at static initialization time.
-struct StaticDescriptorInitializer_dtm_2eevents_2eproto {
-  StaticDescriptorInitializer_dtm_2eevents_2eproto() {
-    protobuf_AddDesc_dtm_2eevents_2eproto();
-  }
-} static_descriptor_initializer_dtm_2eevents_2eproto_;
-
-
-// ===================================================================
-
-const ::std::string events::_default_string1_;
-#ifndef _MSC_VER
-const int events::kHeaderFieldNumber;
-const int events::kErrorCodeFieldNumber;
-const int events::kRmidFieldNumber;
-const int events::kDtmidFieldNumber;
-const int events::kSeqNumFieldNumber;
-const int events::kMsgidFieldNumber;
-const int events::kXaErrorFieldNumber;
-const int events::kPoolSizeFieldNumber;
-const int events::kPoolElemsFieldNumber;
-const int events::kMsgRetriesFieldNumber;
-const int events::kPoolHighFieldNumber;
-const int events::kPoolLowFieldNumber;
-const int events::kPoolMaxFieldNumber;
-const int events::kTxStateFieldNumber;
-const int events::kDataFieldNumber;
-const int events::kData1FieldNumber;
-const int events::kData2FieldNumber;
-const int events::kString1FieldNumber;
-const int events::kNodeFieldNumber;
-const int events::kMsgid2FieldNumber;
-const int events::kOffsetFieldNumber;
-const int events::kTmEventMsgFieldNumber;
-const int events::kData4FieldNumber;
-#endif  // !_MSC_VER
-
-events::events()
-  : ::google::protobuf::Message() {
-  SharedCtor();
-}
-
-void events::InitAsDefaultInstance() {  header_ = const_cast< ::common::event_header*>(&::common::event_header::default_instance());
-}
-
-events::events(const events& from)
-  : ::google::protobuf::Message() {
-  SharedCtor();
-  MergeFrom(from);
-}
-
-void events::SharedCtor() {
-  _cached_size_ = 0;
-  header_ = NULL;
-  error_code_ = 0;
-  rmid_ = 0;
-  dtmid_ = 0;
-  seq_num_ = 0;
-  msgid_ = 0;
-  xa_error_ = GOOGLE_LONGLONG(0);
-  pool_size_ = 0;
-  pool_elems_ = 0;
-  msg_retries_ = 0;
-  pool_high_ = 0;
-  pool_low_ = 0;
-  pool_max_ = 0;
-  tx_state_ = 0;
-  data_ = 0;
-  data1_ = 0;
-  data2_ = GOOGLE_LONGLONG(0);
-  string1_ = const_cast< ::std::string*>(&_default_string1_);
-  node_ = 0;
-  msgid2_ = 0;
-  offset_ = 0;
-  tm_event_msg_ = 0;
-  data4_ = 0u;
-  ::memset(_has_bits_, 0, sizeof(_has_bits_));
-}
-
-events::~events() {
-  SharedDtor();
-}
-
-void events::SharedDtor() {
-  if (string1_ != &_default_string1_) {
-    delete string1_;
-  }
-  if (this != default_instance_) {
-    delete header_;
-  }
-}
-
-const ::google::protobuf::Descriptor* events::descriptor() {
-  protobuf_AssignDescriptorsOnce();
-  return events_descriptor_;
-}
-
-const events& events::default_instance() {
-  if (default_instance_ == NULL) protobuf_AddDesc_dtm_2eevents_2eproto();  return *default_instance_;
-}
-
-events* events::default_instance_ = NULL;
-
-events* events::New() const {
-  return new events;
-}
-
-void events::Clear() {
-  if (_has_bits_[0 / 32] & (0xffu << (0 % 32))) {
-    if (_has_bit(0)) {
-      if (header_ != NULL) header_->::common::event_header::Clear();
-    }
-    error_code_ = 0;
-    rmid_ = 0;
-    dtmid_ = 0;
-    seq_num_ = 0;
-    msgid_ = 0;
-    xa_error_ = GOOGLE_LONGLONG(0);
-    pool_size_ = 0;
-  }
-  if (_has_bits_[8 / 32] & (0xffu << (8 % 32))) {
-    pool_elems_ = 0;
-    msg_retries_ = 0;
-    pool_high_ = 0;
-    pool_low_ = 0;
-    pool_max_ = 0;
-    tx_state_ = 0;
-    data_ = 0;
-    data1_ = 0;
-  }
-  if (_has_bits_[16 / 32] & (0xffu << (16 % 32))) {
-    data2_ = GOOGLE_LONGLONG(0);
-    if (_has_bit(17)) {
-      if (string1_ != &_default_string1_) {
-        string1_->clear();
-      }
-    }
-    node_ = 0;
-    msgid2_ = 0;
-    offset_ = 0;
-    tm_event_msg_ = 0;
-    data4_ = 0u;
-  }
-  ::memset(_has_bits_, 0, sizeof(_has_bits_));
-  mutable_unknown_fields()->Clear();
-}
-
-bool events::MergePartialFromCodedStream(
-    ::google::protobuf::io::CodedInputStream* input) {
-#define DO_(EXPRESSION) if (!(EXPRESSION)) return false
-  ::google::protobuf::uint32 tag;
-  while ((tag = input->ReadTag()) != 0) {
-    switch (::google::protobuf::internal::WireFormat::GetTagFieldNumber(tag)) {
-      // required .common.event_header header = 1;
-      case 1: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_LENGTH_DELIMITED) {
-          goto handle_uninterpreted;
-        }
-        DO_(::google::protobuf::internal::WireFormat::ReadMessageNoVirtual(
-             input, mutable_header()));
-        if (input->ExpectTag(16)) goto parse_error_code;
-        break;
-      }
-      
-      // optional int32 error_code = 2;
-      case 2: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_error_code:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &error_code_));
-        _set_bit(1);
-        if (input->ExpectTag(24)) goto parse_rmid;
-        break;
-      }
-      
-      // optional int32 rmid = 3;
-      case 3: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_rmid:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &rmid_));
-        _set_bit(2);
-        if (input->ExpectTag(32)) goto parse_dtmid;
-        break;
-      }
-      
-      // optional int32 dtmid = 4;
-      case 4: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_dtmid:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &dtmid_));
-        _set_bit(3);
-        if (input->ExpectTag(40)) goto parse_seq_num;
-        break;
-      }
-      
-      // optional int32 seq_num = 5;
-      case 5: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_seq_num:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &seq_num_));
-        _set_bit(4);
-        if (input->ExpectTag(48)) goto parse_msgid;
-        break;
-      }
-      
-      // optional int32 msgid = 6;
-      case 6: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_msgid:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &msgid_));
-        _set_bit(5);
-        if (input->ExpectTag(56)) goto parse_xa_error;
-        break;
-      }
-      
-      // optional int64 xa_error = 7;
-      case 7: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_xa_error:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt64(
-              input, &xa_error_));
-        _set_bit(6);
-        if (input->ExpectTag(64)) goto parse_pool_size;
-        break;
-      }
-      
-      // optional int32 pool_size = 8;
-      case 8: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_pool_size:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &pool_size_));
-        _set_bit(7);
-        if (input->ExpectTag(72)) goto parse_pool_elems;
-        break;
-      }
-      
-      // optional int32 pool_elems = 9;
-      case 9: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_pool_elems:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &pool_elems_));
-        _set_bit(8);
-        if (input->ExpectTag(80)) goto parse_msg_retries;
-        break;
-      }
-      
-      // optional int32 msg_retries = 10;
-      case 10: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_msg_retries:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &msg_retries_));
-        _set_bit(9);
-        if (input->ExpectTag(88)) goto parse_pool_high;
-        break;
-      }
-      
-      // optional int32 pool_high = 11;
-      case 11: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_pool_high:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &pool_high_));
-        _set_bit(10);
-        if (input->ExpectTag(96)) goto parse_pool_low;
-        break;
-      }
-      
-      // optional int32 pool_low = 12;
-      case 12: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_pool_low:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &pool_low_));
-        _set_bit(11);
-        if (input->ExpectTag(104)) goto parse_pool_max;
-        break;
-      }
-      
-      // optional int32 pool_max = 13;
-      case 13: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_pool_max:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &pool_max_));
-        _set_bit(12);
-        if (input->ExpectTag(112)) goto parse_tx_state;
-        break;
-      }
-      
-      // optional int32 tx_state = 14;
-      case 14: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_tx_state:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &tx_state_));
-        _set_bit(13);
-        if (input->ExpectTag(120)) goto parse_data;
-        break;
-      }
-      
-      // optional int32 data = 15;
-      case 15: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_data:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &data_));
-        _set_bit(14);
-        if (input->ExpectTag(128)) goto parse_data1;
-        break;
-      }
-      
-      // optional int32 data1 = 16;
-      case 16: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_data1:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &data1_));
-        _set_bit(15);
-        if (input->ExpectTag(136)) goto parse_data2;
-        break;
-      }
-      
-      // optional int64 data2 = 17;
-      case 17: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_data2:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt64(
-              input, &data2_));
-        _set_bit(16);
-        if (input->ExpectTag(146)) goto parse_string1;
-        break;
-      }
-      
-      // optional string string1 = 18;
-      case 18: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_LENGTH_DELIMITED) {
-          goto handle_uninterpreted;
-        }
-       parse_string1:
-        DO_(::google::protobuf::internal::WireFormat::ReadString(input, mutable_string1()));
-        if (input->ExpectTag(152)) goto parse_node;
-        break;
-      }
-      
-      // optional int32 node = 19;
-      case 19: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_node:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &node_));
-        _set_bit(18);
-        if (input->ExpectTag(160)) goto parse_msgid2;
-        break;
-      }
-      
-      // optional int32 msgid2 = 20;
-      case 20: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_msgid2:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &msgid2_));
-        _set_bit(19);
-        if (input->ExpectTag(168)) goto parse_offset;
-        break;
-      }
-      
-      // optional int32 offset = 21;
-      case 21: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_offset:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &offset_));
-        _set_bit(20);
-        if (input->ExpectTag(176)) goto parse_tm_event_msg;
-        break;
-      }
-      
-      // optional int32 tm_event_msg = 22;
-      case 22: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_tm_event_msg:
-        DO_(::google::protobuf::internal::WireFormat::ReadInt32(
-              input, &tm_event_msg_));
-        _set_bit(21);
-        if (input->ExpectTag(184)) goto parse_data4;
-        break;
-      }
-      
-      // optional uint32 data4 = 23;
-      case 23: {
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) !=
-            ::google::protobuf::internal::WireFormat::WIRETYPE_VARINT) {
-          goto handle_uninterpreted;
-        }
-       parse_data4:
-        DO_(::google::protobuf::internal::WireFormat::ReadUInt32(
-              input, &data4_));
-        _set_bit(22);
-        if (input->ExpectAtEnd()) return true;
-        break;
-      }
-      
-      default: {
-      handle_uninterpreted:
-        if (::google::protobuf::internal::WireFormat::GetTagWireType(tag) ==
-            ::google::protobuf::internal::WireFormat::WIRETYPE_END_GROUP) {
-          return true;
-        }
-        DO_(::google::protobuf::internal::WireFormat::SkipField(
-              input, tag, mutable_unknown_fields()));
-        break;
-      }
-    }
-  }
-  return true;
-#undef DO_
-}
-
-void events::SerializeWithCachedSizes(
-    ::google::protobuf::io::CodedOutputStream* output) const {
-  ::google::protobuf::uint8* raw_buffer = output->GetDirectBufferForNBytesAndAdvance(_cached_size_);
-  if (raw_buffer != NULL) {
-    events::SerializeWithCachedSizesToArray(raw_buffer);
-    return;
-  }
-  
-  // required .common.event_header header = 1;
-  if (_has_bit(0)) {
-    ::google::protobuf::internal::WireFormat::WriteMessageNoVirtual(1, this->header(), output);
-  }
-  
-  // optional int32 error_code = 2;
-  if (_has_bit(1)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(2, this->error_code(), output);
-  }
-  
-  // optional int32 rmid = 3;
-  if (_has_bit(2)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(3, this->rmid(), output);
-  }
-  
-  // optional int32 dtmid = 4;
-  if (_has_bit(3)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(4, this->dtmid(), output);
-  }
-  
-  // optional int32 seq_num = 5;
-  if (_has_bit(4)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(5, this->seq_num(), output);
-  }
-  
-  // optional int32 msgid = 6;
-  if (_has_bit(5)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(6, this->msgid(), output);
-  }
-  
-  // optional int64 xa_error = 7;
-  if (_has_bit(6)) {
-    ::google::protobuf::internal::WireFormat::WriteInt64(7, this->xa_error(), output);
-  }
-  
-  // optional int32 pool_size = 8;
-  if (_has_bit(7)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(8, this->pool_size(), output);
-  }
-  
-  // optional int32 pool_elems = 9;
-  if (_has_bit(8)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(9, this->pool_elems(), output);
-  }
-  
-  // optional int32 msg_retries = 10;
-  if (_has_bit(9)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(10, this->msg_retries(), output);
-  }
-  
-  // optional int32 pool_high = 11;
-  if (_has_bit(10)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(11, this->pool_high(), output);
-  }
-  
-  // optional int32 pool_low = 12;
-  if (_has_bit(11)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(12, this->pool_low(), output);
-  }
-  
-  // optional int32 pool_max = 13;
-  if (_has_bit(12)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(13, this->pool_max(), output);
-  }
-  
-  // optional int32 tx_state = 14;
-  if (_has_bit(13)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(14, this->tx_state(), output);
-  }
-  
-  // optional int32 data = 15;
-  if (_has_bit(14)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(15, this->data(), output);
-  }
-  
-  // optional int32 data1 = 16;
-  if (_has_bit(15)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(16, this->data1(), output);
-  }
-  
-  // optional int64 data2 = 17;
-  if (_has_bit(16)) {
-    ::google::protobuf::internal::WireFormat::WriteInt64(17, this->data2(), output);
-  }
-  
-  // optional string string1 = 18;
-  if (_has_bit(17)) {
-    ::google::protobuf::internal::WireFormat::WriteString(18, this->string1(), output);
-  }
-  
-  // optional int32 node = 19;
-  if (_has_bit(18)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(19, this->node(), output);
-  }
-  
-  // optional int32 msgid2 = 20;
-  if (_has_bit(19)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(20, this->msgid2(), output);
-  }
-  
-  // optional int32 offset = 21;
-  if (_has_bit(20)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(21, this->offset(), output);
-  }
-  
-  // optional int32 tm_event_msg = 22;
-  if (_has_bit(21)) {
-    ::google::protobuf::internal::WireFormat::WriteInt32(22, this->tm_event_msg(), output);
-  }
-  
-  // optional uint32 data4 = 23;
-  if (_has_bit(22)) {
-    ::google::protobuf::internal::WireFormat::WriteUInt32(23, this->data4(), output);
-  }
-  
-  if (!unknown_fields().empty()) {
-    ::google::protobuf::internal::WireFormat::SerializeUnknownFields(
-        unknown_fields(), output);
-  }
-}
-
-::google::protobuf::uint8* events::SerializeWithCachedSizesToArray(
-    ::google::protobuf::uint8* target) const {
-  // required .common.event_header header = 1;
-  if (_has_bit(0)) {
-    target = ::google::protobuf::internal::WireFormat::WriteMessageNoVirtualToArray(1, this->header(), target);
-  }
-  
-  // optional int32 error_code = 2;
-  if (_has_bit(1)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(2, this->error_code(), target);
-  }
-  
-  // optional int32 rmid = 3;
-  if (_has_bit(2)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(3, this->rmid(), target);
-  }
-  
-  // optional int32 dtmid = 4;
-  if (_has_bit(3)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(4, this->dtmid(), target);
-  }
-  
-  // optional int32 seq_num = 5;
-  if (_has_bit(4)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(5, this->seq_num(), target);
-  }
-  
-  // optional int32 msgid = 6;
-  if (_has_bit(5)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(6, this->msgid(), target);
-  }
-  
-  // optional int64 xa_error = 7;
-  if (_has_bit(6)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt64ToArray(7, this->xa_error(), target);
-  }
-  
-  // optional int32 pool_size = 8;
-  if (_has_bit(7)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(8, this->pool_size(), target);
-  }
-  
-  // optional int32 pool_elems = 9;
-  if (_has_bit(8)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(9, this->pool_elems(), target);
-  }
-  
-  // optional int32 msg_retries = 10;
-  if (_has_bit(9)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(10, this->msg_retries(), target);
-  }
-  
-  // optional int32 pool_high = 11;
-  if (_has_bit(10)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(11, this->pool_high(), target);
-  }
-  
-  // optional int32 pool_low = 12;
-  if (_has_bit(11)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(12, this->pool_low(), target);
-  }
-  
-  // optional int32 pool_max = 13;
-  if (_has_bit(12)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(13, this->pool_max(), target);
-  }
-  
-  // optional int32 tx_state = 14;
-  if (_has_bit(13)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(14, this->tx_state(), target);
-  }
-  
-  // optional int32 data = 15;
-  if (_has_bit(14)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(15, this->data(), target);
-  }
-  
-  // optional int32 data1 = 16;
-  if (_has_bit(15)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(16, this->data1(), target);
-  }
-  
-  // optional int64 data2 = 17;
-  if (_has_bit(16)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt64ToArray(17, this->data2(), target);
-  }
-  
-  // optional string string1 = 18;
-  if (_has_bit(17)) {
-    target = ::google::protobuf::internal::WireFormat::WriteStringToArray(18, this->string1(), target);
-  }
-  
-  // optional int32 node = 19;
-  if (_has_bit(18)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(19, this->node(), target);
-  }
-  
-  // optional int32 msgid2 = 20;
-  if (_has_bit(19)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(20, this->msgid2(), target);
-  }
-  
-  // optional int32 offset = 21;
-  if (_has_bit(20)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(21, this->offset(), target);
-  }
-  
-  // optional int32 tm_event_msg = 22;
-  if (_has_bit(21)) {
-    target = ::google::protobuf::internal::WireFormat::WriteInt32ToArray(22, this->tm_event_msg(), target);
-  }
-  
-  // optional uint32 data4 = 23;
-  if (_has_bit(22)) {
-    target = ::google::protobuf::internal::WireFormat::WriteUInt32ToArray(23, this->data4(), target);
-  }
-  
-  if (!unknown_fields().empty()) {
-    target = ::google::protobuf::internal::WireFormat::SerializeUnknownFieldsToArray(
-        unknown_fields(), target);
-  }
-  return target;
-}
-
-int events::ByteSize() const {
-  int total_size = 0;
-  
-  if (_has_bits_[0 / 32] & (0xffu << (0 % 32))) {
-    // required .common.event_header header = 1;
-    if (has_header()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::MessageSizeNoVirtual(
-          this->header());
-    }
-    
-    // optional int32 error_code = 2;
-    if (has_error_code()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->error_code());
-    }
-    
-    // optional int32 rmid = 3;
-    if (has_rmid()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->rmid());
-    }
-    
-    // optional int32 dtmid = 4;
-    if (has_dtmid()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->dtmid());
-    }
-    
-    // optional int32 seq_num = 5;
-    if (has_seq_num()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->seq_num());
-    }
-    
-    // optional int32 msgid = 6;
-    if (has_msgid()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->msgid());
-    }
-    
-    // optional int64 xa_error = 7;
-    if (has_xa_error()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int64Size(
-          this->xa_error());
-    }
-    
-    // optional int32 pool_size = 8;
-    if (has_pool_size()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->pool_size());
-    }
-    
-  }
-  if (_has_bits_[8 / 32] & (0xffu << (8 % 32))) {
-    // optional int32 pool_elems = 9;
-    if (has_pool_elems()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->pool_elems());
-    }
-    
-    // optional int32 msg_retries = 10;
-    if (has_msg_retries()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->msg_retries());
-    }
-    
-    // optional int32 pool_high = 11;
-    if (has_pool_high()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->pool_high());
-    }
-    
-    // optional int32 pool_low = 12;
-    if (has_pool_low()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->pool_low());
-    }
-    
-    // optional int32 pool_max = 13;
-    if (has_pool_max()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->pool_max());
-    }
-    
-    // optional int32 tx_state = 14;
-    if (has_tx_state()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->tx_state());
-    }
-    
-    // optional int32 data = 15;
-    if (has_data()) {
-      total_size += 1 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->data());
-    }
-    
-    // optional int32 data1 = 16;
-    if (has_data1()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->data1());
-    }
-    
-  }
-  if (_has_bits_[16 / 32] & (0xffu << (16 % 32))) {
-    // optional int64 data2 = 17;
-    if (has_data2()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int64Size(
-          this->data2());
-    }
-    
-    // optional string string1 = 18;
-    if (has_string1()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::StringSize(this->string1());
-    }
-    
-    // optional int32 node = 19;
-    if (has_node()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->node());
-    }
-    
-    // optional int32 msgid2 = 20;
-    if (has_msgid2()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->msgid2());
-    }
-    
-    // optional int32 offset = 21;
-    if (has_offset()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->offset());
-    }
-    
-    // optional int32 tm_event_msg = 22;
-    if (has_tm_event_msg()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::Int32Size(
-          this->tm_event_msg());
-    }
-    
-    // optional uint32 data4 = 23;
-    if (has_data4()) {
-      total_size += 2 +
-        ::google::protobuf::internal::WireFormat::UInt32Size(
-          this->data4());
-    }
-    
-  }
-  if (!unknown_fields().empty()) {
-    total_size +=
-      ::google::protobuf::internal::WireFormat::ComputeUnknownFieldsSize(
-        unknown_fields());
-  }
-  _cached_size_ = total_size;
-  return total_size;
-}
-
-void events::MergeFrom(const ::google::protobuf::Message& from) {
-  GOOGLE_CHECK_NE(&from, this);
-  const events* source =
-    ::google::protobuf::internal::dynamic_cast_if_available<const events*>(
-      &from);
-  if (source == NULL) {
-    ::google::protobuf::internal::ReflectionOps::Merge(from, this);
-  } else {
-    MergeFrom(*source);
-  }
-}
-
-void events::MergeFrom(const events& from) {
-  GOOGLE_CHECK_NE(&from, this);
-  if (from._has_bits_[0 / 32] & (0xffu << (0 % 32))) {
-    if (from._has_bit(0)) {
-      mutable_header()->::common::event_header::MergeFrom(from.header());
-    }
-    if (from._has_bit(1)) {
-      set_error_code(from.error_code());
-    }
-    if (from._has_bit(2)) {
-      set_rmid(from.rmid());
-    }
-    if (from._has_bit(3)) {
-      set_dtmid(from.dtmid());
-    }
-    if (from._has_bit(4)) {
-      set_seq_num(from.seq_num());
-    }
-    if (from._has_bit(5)) {
-      set_msgid(from.msgid());
-    }
-    if (from._has_bit(6)) {
-      set_xa_error(from.xa_error());
-    }
-    if (from._has_bit(7)) {
-      set_pool_size(from.pool_size());
-    }
-  }
-  if (from._has_bits_[8 / 32] & (0xffu << (8 % 32))) {
-    if (from._has_bit(8)) {
-      set_pool_elems(from.pool_elems());
-    }
-    if (from._has_bit(9)) {
-      set_msg_retries(from.msg_retries());
-    }
-    if (from._has_bit(10)) {
-      set_pool_high(from.pool_high());
-    }
-    if (from._has_bit(11)) {
-      set_pool_low(from.pool_low());
-    }
-    if (from._has_bit(12)) {
-      set_pool_max(from.pool_max());
-    }
-    if (from._has_bit(13)) {
-      set_tx_state(from.tx_state());
-    }
-    if (from._has_bit(14)) {
-      set_data(from.data());
-    }
-    if (from._has_bit(15)) {
-      set_data1(from.data1());
-    }
-  }
-  if (from._has_bits_[16 / 32] & (0xffu << (16 % 32))) {
-    if (from._has_bit(16)) {
-      set_data2(from.data2());
-    }
-    if (from._has_bit(17)) {
-      set_string1(from.string1());
-    }
-    if (from._has_bit(18)) {
-      set_node(from.node());
-    }
-    if (from._has_bit(19)) {
-      set_msgid2(from.msgid2());
-    }
-    if (from._has_bit(20)) {
-      set_offset(from.offset());
-    }
-    if (from._has_bit(21)) {
-      set_tm_event_msg(from.tm_event_msg());
-    }
-    if (from._has_bit(22)) {
-      set_data4(from.data4());
-    }
-  }
-  mutable_unknown_fields()->MergeFrom(from.unknown_fields());
-}
-
-void events::CopyFrom(const ::google::protobuf::Message& from) {
-  if (&from == this) return;
-  Clear();
-  MergeFrom(from);
-}
-
-void events::CopyFrom(const events& from) {
-  if (&from == this) return;
-  Clear();
-  MergeFrom(from);
-}
-
-void events::Swap(events* other) {
-  if (other != this) {
-    std::swap(header_, other->header_);
-    std::swap(error_code_, other->error_code_);
-    std::swap(rmid_, other->rmid_);
-    std::swap(dtmid_, other->dtmid_);
-    std::swap(seq_num_, other->seq_num_);
-    std::swap(msgid_, other->msgid_);
-    std::swap(xa_error_, other->xa_error_);
-    std::swap(pool_size_, other->pool_size_);
-    std::swap(pool_elems_, other->pool_elems_);
-    std::swap(msg_retries_, other->msg_retries_);
-    std::swap(pool_high_, other->pool_high_);
-    std::swap(pool_low_, other->pool_low_);
-    std::swap(pool_max_, other->pool_max_);
-    std::swap(tx_state_, other->tx_state_);
-    std::swap(data_, other->data_);
-    std::swap(data1_, other->data1_);
-    std::swap(data2_, other->data2_);
-    std::swap(string1_, other->string1_);
-    std::swap(node_, other->node_);
-    std::swap(msgid2_, other->msgid2_);
-    std::swap(offset_, other->offset_);
-    std::swap(tm_event_msg_, other->tm_event_msg_);
-    std::swap(data4_, other->data4_);
-    std::swap(_has_bits_[0], other->_has_bits_[0]);
-    _unknown_fields_.Swap(&other->_unknown_fields_);
-    std::swap(_cached_size_, other->_cached_size_);
-  }
-}
-
-bool events::IsInitialized() const {
-  if ((_has_bits_[0] & 0x00000001) != 0x00000001) return false;
-  
-  if (has_header()) {
-    if (!this->header().IsInitialized()) return false;
-  }
-  return true;
-}
-
-const ::google::protobuf::Descriptor* events::GetDescriptor() const {
-  return descriptor();
-}
-
-const ::google::protobuf::Reflection* events::GetReflection() const {
-  protobuf_AssignDescriptorsOnce();
-  return events_reflection_;
-}
-
-}  // namespace dtm

http://git-wip-us.apache.org/repos/asf/incubator-trafodion/blob/852e01a7/core/sqf/src/tm/dtm.events.pb.h
----------------------------------------------------------------------
diff --git a/core/sqf/src/tm/dtm.events.pb.h b/core/sqf/src/tm/dtm.events.pb.h
deleted file mode 100644
index 67db66a..0000000
--- a/core/sqf/src/tm/dtm.events.pb.h
+++ /dev/null
@@ -1,709 +0,0 @@
-// Generated by the protocol buffer compiler.  DO NOT EDIT!
-
-#ifndef PROTOBUF_dtm_2eevents_2eproto__INCLUDED
-#define PROTOBUF_dtm_2eevents_2eproto__INCLUDED
-
-#include <string>
-
-#include <google/protobuf/stubs/common.h>
-
-#if GOOGLE_PROTOBUF_VERSION < 2001000
-#error This file was generated by a newer version of protoc which is
-#error incompatible with your Protocol Buffer headers.  Please update
-#error your headers.
-#endif
-#if 2001000 < GOOGLE_PROTOBUF_MIN_PROTOC_VERSION
-#error This file was generated by an older version of protoc which is
-#error incompatible with your Protocol Buffer headers.  Please
-#error regenerate this file with a newer version of protoc.
-#endif
-
-#include <google/protobuf/generated_message_reflection.h>
-#include <google/protobuf/repeated_field.h>
-#include <google/protobuf/extension_set.h>
-#include "common.event_header.pb.h"
-
-namespace dtm {
-
-// Internal implementation detail -- do not call these.
-void  protobuf_AddDesc_dtm_2eevents_2eproto();
-void protobuf_AssignDesc_dtm_2eevents_2eproto();
-void protobuf_ShutdownFile_dtm_2eevents_2eproto();
-
-class events;
-
-// ===================================================================
-
-class events : public ::google::protobuf::Message {
- public:
-  events();
-  virtual ~events();
-  
-  events(const events& from);
-  
-  inline events& operator=(const events& from) {
-    CopyFrom(from);
-    return *this;
-  }
-  
-  inline const ::google::protobuf::UnknownFieldSet& unknown_fields() const {
-    return _unknown_fields_;
-  }
-  
-  inline ::google::protobuf::UnknownFieldSet* mutable_unknown_fields() {
-    return &_unknown_fields_;
-  }
-  
-  static const ::google::protobuf::Descriptor* descriptor();
-  static const events& default_instance();
-  void Swap(events* other);
-  
-  // implements Message ----------------------------------------------
-  
-  events* New() const;
-  void CopyFrom(const ::google::protobuf::Message& from);
-  void MergeFrom(const ::google::protobuf::Message& from);
-  void CopyFrom(const events& from);
-  void MergeFrom(const events& from);
-  void Clear();
-  bool IsInitialized() const;
-  
-  int ByteSize() const;
-  bool MergePartialFromCodedStream(
-      ::google::protobuf::io::CodedInputStream* input);
-  void SerializeWithCachedSizes(
-      ::google::protobuf::io::CodedOutputStream* output) const;
-  ::google::protobuf::uint8* SerializeWithCachedSizesToArray(::google::protobuf::uint8* output) const;
-  int GetCachedSize() const { return _cached_size_; }
-  private:
-  void SharedCtor();
-  void SharedDtor();
-  void SetCachedSize(int size) const { _cached_size_ = size; }
-  public:
-  
-  const ::google::protobuf::Descriptor* GetDescriptor() const;
-  const ::google::protobuf::Reflection* GetReflection() const;
-  
-  // nested types ----------------------------------------------------
-  
-  // accessors -------------------------------------------------------
-  
-  // required .common.event_header header = 1;
-  inline bool has_header() const;
-  inline void clear_header();
-  static const int kHeaderFieldNumber = 1;
-  inline const ::common::event_header& header() const;
-  inline ::common::event_header* mutable_header();
-  
-  // optional int32 error_code = 2;
-  inline bool has_error_code() const;
-  inline void clear_error_code();
-  static const int kErrorCodeFieldNumber = 2;
-  inline ::google::protobuf::int32 error_code() const;
-  inline void set_error_code(::google::protobuf::int32 value);
-  
-  // optional int32 rmid = 3;
-  inline bool has_rmid() const;
-  inline void clear_rmid();
-  static const int kRmidFieldNumber = 3;
-  inline ::google::protobuf::int32 rmid() const;
-  inline void set_rmid(::google::protobuf::int32 value);
-  
-  // optional int32 dtmid = 4;
-  inline bool has_dtmid() const;
-  inline void clear_dtmid();
-  static const int kDtmidFieldNumber = 4;
-  inline ::google::protobuf::int32 dtmid() const;
-  inline void set_dtmid(::google::protobuf::int32 value);
-  
-  // optional int32 seq_num = 5;
-  inline bool has_seq_num() const;
-  inline void clear_seq_num();
-  static const int kSeqNumFieldNumber = 5;
-  inline ::google::protobuf::int32 seq_num() const;
-  inline void set_seq_num(::google::protobuf::int32 value);
-  
-  // optional int32 msgid = 6;
-  inline bool has_msgid() const;
-  inline void clear_msgid();
-  static const int kMsgidFieldNumber = 6;
-  inline ::google::protobuf::int32 msgid() const;
-  inline void set_msgid(::google::protobuf::int32 value);
-  
-  // optional int64 xa_error = 7;
-  inline bool has_xa_error() const;
-  inline void clear_xa_error();
-  static const int kXaErrorFieldNumber = 7;
-  inline ::google::protobuf::int64 xa_error() const;
-  inline void set_xa_error(::google::protobuf::int64 value);
-  
-  // optional int32 pool_size = 8;
-  inline bool has_pool_size() const;
-  inline void clear_pool_size();
-  static const int kPoolSizeFieldNumber = 8;
-  inline ::google::protobuf::int32 pool_size() const;
-  inline void set_pool_size(::google::protobuf::int32 value);
-  
-  // optional int32 pool_elems = 9;
-  inline bool has_pool_elems() const;
-  inline void clear_pool_elems();
-  static const int kPoolElemsFieldNumber = 9;
-  inline ::google::protobuf::int32 pool_elems() const;
-  inline void set_pool_elems(::google::protobuf::int32 value);
-  
-  // optional int32 msg_retries = 10;
-  inline bool has_msg_retries() const;
-  inline void clear_msg_retries();
-  static const int kMsgRetriesFieldNumber = 10;
-  inline ::google::protobuf::int32 msg_retries() const;
-  inline void set_msg_retries(::google::protobuf::int32 value);
-  
-  // optional int32 pool_high = 11;
-  inline bool has_pool_high() const;
-  inline void clear_pool_high();
-  static const int kPoolHighFieldNumber = 11;
-  inline ::google::protobuf::int32 pool_high() const;
-  inline void set_pool_high(::google::protobuf::int32 value);
-  
-  // optional int32 pool_low = 12;
-  inline bool has_pool_low() const;
-  inline void clear_pool_low();
-  static const int kPoolLowFieldNumber = 12;
-  inline ::google::protobuf::int32 pool_low() const;
-  inline void set_pool_low(::google::protobuf::int32 value);
-  
-  // optional int32 pool_max = 13;
-  inline bool has_pool_max() const;
-  inline void clear_pool_max();
-  static const int kPoolMaxFieldNumber = 13;
-  inline ::google::protobuf::int32 pool_max() const;
-  inline void set_pool_max(::google::protobuf::int32 value);
-  
-  // optional int32 tx_state = 14;
-  inline bool has_tx_state() const;
-  inline void clear_tx_state();
-  static const int kTxStateFieldNumber = 14;
-  inline ::google::protobuf::int32 tx_state() const;
-  inline void set_tx_state(::google::protobuf::int32 value);
-  
-  // optional int32 data = 15;
-  inline bool has_data() const;
-  inline void clear_data();
-  static const int kDataFieldNumber = 15;
-  inline ::google::protobuf::int32 data() const;
-  inline void set_data(::google::protobuf::int32 value);
-  
-  // optional int32 data1 = 16;
-  inline bool has_data1() const;
-  inline void clear_data1();
-  static const int kData1FieldNumber = 16;
-  inline ::google::protobuf::int32 data1() const;
-  inline void set_data1(::google::protobuf::int32 value);
-  
-  // optional int64 data2 = 17;
-  inline bool has_data2() const;
-  inline void clear_data2();
-  static const int kData2FieldNumber = 17;
-  inline ::google::protobuf::int64 data2() const;
-  inline void set_data2(::google::protobuf::int64 value);
-  
-  // optional string string1 = 18;
-  inline bool has_string1() const;
-  inline void clear_string1();
-  static const int kString1FieldNumber = 18;
-  inline const ::std::string& string1() const;
-  inline void set_string1(const ::std::string& value);
-  inline void set_string1(const char* value);
-  inline void set_string1(const char* value, size_t size);
-  inline ::std::string* mutable_string1();
-  
-  // optional int32 node = 19;
-  inline bool has_node() const;
-  inline void clear_node();
-  static const int kNodeFieldNumber = 19;
-  inline ::google::protobuf::int32 node() const;
-  inline void set_node(::google::protobuf::int32 value);
-  
-  // optional int32 msgid2 = 20;
-  inline bool has_msgid2() const;
-  inline void clear_msgid2();
-  static const int kMsgid2FieldNumber = 20;
-  inline ::google::protobuf::int32 msgid2() const;
-  inline void set_msgid2(::google::protobuf::int32 value);
-  
-  // optional int32 offset = 21;
-  inline bool has_offset() const;
-  inline void clear_offset();
-  static const int kOffsetFieldNumber = 21;
-  inline ::google::protobuf::int32 offset() const;
-  inline void set_offset(::google::protobuf::int32 value);
-  
-  // optional int32 tm_event_msg = 22;
-  inline bool has_tm_event_msg() const;
-  inline void clear_tm_event_msg();
-  static const int kTmEventMsgFieldNumber = 22;
-  inline ::google::protobuf::int32 tm_event_msg() const;
-  inline void set_tm_event_msg(::google::protobuf::int32 value);
-  
-  // optional uint32 data4 = 23;
-  inline bool has_data4() const;
-  inline void clear_data4();
-  static const int kData4FieldNumber = 23;
-  inline ::google::protobuf::uint32 data4() const;
-  inline void set_data4(::google::protobuf::uint32 value);
-  
- private:
-  ::google::protobuf::UnknownFieldSet _unknown_fields_;
-  mutable int _cached_size_;
-  
-  ::common::event_header* header_;
-  ::google::protobuf::int32 error_code_;
-  ::google::protobuf::int32 rmid_;
-  ::google::protobuf::int32 dtmid_;
-  ::google::protobuf::int32 seq_num_;
-  ::google::protobuf::int32 msgid_;
-  ::google::protobuf::int64 xa_error_;
-  ::google::protobuf::int32 pool_size_;
-  ::google::protobuf::int32 pool_elems_;
-  ::google::protobuf::int32 msg_retries_;
-  ::google::protobuf::int32 pool_high_;
-  ::google::protobuf::int32 pool_low_;
-  ::google::protobuf::int32 pool_max_;
-  ::google::protobuf::int32 tx_state_;
-  ::google::protobuf::int32 data_;
-  ::google::protobuf::int32 data1_;
-  ::google::protobuf::int64 data2_;
-  ::std::string* string1_;
-  static const ::std::string _default_string1_;
-  ::google::protobuf::int32 node_;
-  ::google::protobuf::int32 msgid2_;
-  ::google::protobuf::int32 offset_;
-  ::google::protobuf::int32 tm_event_msg_;
-  ::google::protobuf::uint32 data4_;
-  friend void  protobuf_AddDesc_dtm_2eevents_2eproto();
-  friend void protobuf_AssignDesc_dtm_2eevents_2eproto();
-  friend void protobuf_ShutdownFile_dtm_2eevents_2eproto();
-  ::google::protobuf::uint32 _has_bits_[(23 + 31) / 32];
-  
-  // WHY DOES & HAVE LOWER PRECEDENCE THAN != !?
-  inline bool _has_bit(int index) const {
-    return (_has_bits_[index / 32] & (1u << (index % 32))) != 0;
-  }
-  inline void _set_bit(int index) {
-    _has_bits_[index / 32] |= (1u << (index % 32));
-  }
-  inline void _clear_bit(int index) {
-    _has_bits_[index / 32] &= ~(1u << (index % 32));
-  }
-  
-  void InitAsDefaultInstance();
-  static events* default_instance_;
-};
-// ===================================================================
-
-
-// ===================================================================
-
-
-// ===================================================================
-
-// events
-
-// required .common.event_header header = 1;
-inline bool events::has_header() const {
-  return _has_bit(0);
-}
-inline void events::clear_header() {
-  if (header_ != NULL) header_->::common::event_header::Clear();
-  _clear_bit(0);
-}
-inline const ::common::event_header& events::header() const {
-  return header_ != NULL ? *header_ : *default_instance_->header_;
-}
-inline ::common::event_header* events::mutable_header() {
-  _set_bit(0);
-  if (header_ == NULL) header_ = new ::common::event_header;
-  return header_;
-}
-
-// optional int32 error_code = 2;
-inline bool events::has_error_code() const {
-  return _has_bit(1);
-}
-inline void events::clear_error_code() {
-  error_code_ = 0;
-  _clear_bit(1);
-}
-inline ::google::protobuf::int32 events::error_code() const {
-  return error_code_;
-}
-inline void events::set_error_code(::google::protobuf::int32 value) {
-  _set_bit(1);
-  error_code_ = value;
-}
-
-// optional int32 rmid = 3;
-inline bool events::has_rmid() const {
-  return _has_bit(2);
-}
-inline void events::clear_rmid() {
-  rmid_ = 0;
-  _clear_bit(2);
-}
-inline ::google::protobuf::int32 events::rmid() const {
-  return rmid_;
-}
-inline void events::set_rmid(::google::protobuf::int32 value) {
-  _set_bit(2);
-  rmid_ = value;
-}
-
-// optional int32 dtmid = 4;
-inline bool events::has_dtmid() const {
-  return _has_bit(3);
-}
-inline void events::clear_dtmid() {
-  dtmid_ = 0;
-  _clear_bit(3);
-}
-inline ::google::protobuf::int32 events::dtmid() const {
-  return dtmid_;
-}
-inline void events::set_dtmid(::google::protobuf::int32 value) {
-  _set_bit(3);
-  dtmid_ = value;
-}
-
-// optional int32 seq_num = 5;
-inline bool events::has_seq_num() const {
-  return _has_bit(4);
-}
-inline void events::clear_seq_num() {
-  seq_num_ = 0;
-  _clear_bit(4);
-}
-inline ::google::protobuf::int32 events::seq_num() const {
-  return seq_num_;
-}
-inline void events::set_seq_num(::google::protobuf::int32 value) {
-  _set_bit(4);
-  seq_num_ = value;
-}
-
-// optional int32 msgid = 6;
-inline bool events::has_msgid() const {
-  return _has_bit(5);
-}
-inline void events::clear_msgid() {
-  msgid_ = 0;
-  _clear_bit(5);
-}
-inline ::google::protobuf::int32 events::msgid() const {
-  return msgid_;
-}
-inline void events::set_msgid(::google::protobuf::int32 value) {
-  _set_bit(5);
-  msgid_ = value;
-}
-
-// optional int64 xa_error = 7;
-inline bool events::has_xa_error() const {
-  return _has_bit(6);
-}
-inline void events::clear_xa_error() {
-  xa_error_ = GOOGLE_LONGLONG(0);
-  _clear_bit(6);
-}
-inline ::google::protobuf::int64 events::xa_error() const {
-  return xa_error_;
-}
-inline void events::set_xa_error(::google::protobuf::int64 value) {
-  _set_bit(6);
-  xa_error_ = value;
-}
-
-// optional int32 pool_size = 8;
-inline bool events::has_pool_size() const {
-  return _has_bit(7);
-}
-inline void events::clear_pool_size() {
-  pool_size_ = 0;
-  _clear_bit(7);
-}
-inline ::google::protobuf::int32 events::pool_size() const {
-  return pool_size_;
-}
-inline void events::set_pool_size(::google::protobuf::int32 value) {
-  _set_bit(7);
-  pool_size_ = value;
-}
-
-// optional int32 pool_elems = 9;
-inline bool events::has_pool_elems() const {
-  return _has_bit(8);
-}
-inline void events::clear_pool_elems() {
-  pool_elems_ = 0;
-  _clear_bit(8);
-}
-inline ::google::protobuf::int32 events::pool_elems() const {
-  return pool_elems_;
-}
-inline void events::set_pool_elems(::google::protobuf::int32 value) {
-  _set_bit(8);
-  pool_elems_ = value;
-}
-
-// optional int32 msg_retries = 10;
-inline bool events::has_msg_retries() const {
-  return _has_bit(9);
-}
-inline void events::clear_msg_retries() {
-  msg_retries_ = 0;
-  _clear_bit(9);
-}
-inline ::google::protobuf::int32 events::msg_retries() const {
-  return msg_retries_;
-}
-inline void events::set_msg_retries(::google::protobuf::int32 value) {
-  _set_bit(9);
-  msg_retries_ = value;
-}
-
-// optional int32 pool_high = 11;
-inline bool events::has_pool_high() const {
-  return _has_bit(10);
-}
-inline void events::clear_pool_high() {
-  pool_high_ = 0;
-  _clear_bit(10);
-}
-inline ::google::protobuf::int32 events::pool_high() const {
-  return pool_high_;
-}
-inline void events::set_pool_high(::google::protobuf::int32 value) {
-  _set_bit(10);
-  pool_high_ = value;
-}
-
-// optional int32 pool_low = 12;
-inline bool events::has_pool_low() const {
-  return _has_bit(11);
-}
-inline void events::clear_pool_low() {
-  pool_low_ = 0;
-  _clear_bit(11);
-}
-inline ::google::protobuf::int32 events::pool_low() const {
-  return pool_low_;
-}
-inline void events::set_pool_low(::google::protobuf::int32 value) {
-  _set_bit(11);
-  pool_low_ = value;
-}
-
-// optional int32 pool_max = 13;
-inline bool events::has_pool_max() const {
-  return _has_bit(12);
-}
-inline void events::clear_pool_max() {
-  pool_max_ = 0;
-  _clear_bit(12);
-}
-inline ::google::protobuf::int32 events::pool_max() const {
-  return pool_max_;
-}
-inline void events::set_pool_max(::google::protobuf::int32 value) {
-  _set_bit(12);
-  pool_max_ = value;
-}
-
-// optional int32 tx_state = 14;
-inline bool events::has_tx_state() const {
-  return _has_bit(13);
-}
-inline void events::clear_tx_state() {
-  tx_state_ = 0;
-  _clear_bit(13);
-}
-inline ::google::protobuf::int32 events::tx_state() const {
-  return tx_state_;
-}
-inline void events::set_tx_state(::google::protobuf::int32 value) {
-  _set_bit(13);
-  tx_state_ = value;
-}
-
-// optional int32 data = 15;
-inline bool events::has_data() const {
-  return _has_bit(14);
-}
-inline void events::clear_data() {
-  data_ = 0;
-  _clear_bit(14);
-}
-inline ::google::protobuf::int32 events::data() const {
-  return data_;
-}
-inline void events::set_data(::google::protobuf::int32 value) {
-  _set_bit(14);
-  data_ = value;
-}
-
-// optional int32 data1 = 16;
-inline bool events::has_data1() const {
-  return _has_bit(15);
-}
-inline void events::clear_data1() {
-  data1_ = 0;
-  _clear_bit(15);
-}
-inline ::google::protobuf::int32 events::data1() const {
-  return data1_;
-}
-inline void events::set_data1(::google::protobuf::int32 value) {
-  _set_bit(15);
-  data1_ = value;
-}
-
-// optional int64 data2 = 17;
-inline bool events::has_data2() const {
-  return _has_bit(16);
-}
-inline void events::clear_data2() {
-  data2_ = GOOGLE_LONGLONG(0);
-  _clear_bit(16);
-}
-inline ::google::protobuf::int64 events::data2() const {
-  return data2_;
-}
-inline void events::set_data2(::google::protobuf::int64 value) {
-  _set_bit(16);
-  data2_ = value;
-}
-
-// optional string string1 = 18;
-inline bool events::has_string1() const {
-  return _has_bit(17);
-}
-inline void events::clear_string1() {
-  if (string1_ != &_default_string1_) {
-    string1_->clear();
-  }
-  _clear_bit(17);
-}
-inline const ::std::string& events::string1() const {
-  return *string1_;
-}
-inline void events::set_string1(const ::std::string& value) {
-  _set_bit(17);
-  if (string1_ == &_default_string1_) {
-    string1_ = new ::std::string;
-  }
-  string1_->assign(value);
-}
-inline void events::set_string1(const char* value) {
-  _set_bit(17);
-  if (string1_ == &_default_string1_) {
-    string1_ = new ::std::string;
-  }
-  string1_->assign(value);
-}
-inline void events::set_string1(const char* value, size_t size) {
-  _set_bit(17);
-  if (string1_ == &_default_string1_) {
-    string1_ = new ::std::string;
-  }
-  string1_->assign(reinterpret_cast<const char*>(value), size);
-}
-inline ::std::string* events::mutable_string1() {
-  _set_bit(17);
-  if (string1_ == &_default_string1_) {
-    string1_ = new ::std::string;
-  }
-  return string1_;
-}
-
-// optional int32 node = 19;
-inline bool events::has_node() const {
-  return _has_bit(18);
-}
-inline void events::clear_node() {
-  node_ = 0;
-  _clear_bit(18);
-}
-inline ::google::protobuf::int32 events::node() const {
-  return node_;
-}
-inline void events::set_node(::google::protobuf::int32 value) {
-  _set_bit(18);
-  node_ = value;
-}
-
-// optional int32 msgid2 = 20;
-inline bool events::has_msgid2() const {
-  return _has_bit(19);
-}
-inline void events::clear_msgid2() {
-  msgid2_ = 0;
-  _clear_bit(19);
-}
-inline ::google::protobuf::int32 events::msgid2() const {
-  return msgid2_;
-}
-inline void events::set_msgid2(::google::protobuf::int32 value) {
-  _set_bit(19);
-  msgid2_ = value;
-}
-
-// optional int32 offset = 21;
-inline bool events::has_offset() const {
-  return _has_bit(20);
-}
-inline void events::clear_offset() {
-  offset_ = 0;
-  _clear_bit(20);
-}
-inline ::google::protobuf::int32 events::offset() const {
-  return offset_;
-}
-inline void events::set_offset(::google::protobuf::int32 value) {
-  _set_bit(20);
-  offset_ = value;
-}
-
-// optional int32 tm_event_msg = 22;
-inline bool events::has_tm_event_msg() const {
-  return _has_bit(21);
-}
-inline void events::clear_tm_event_msg() {
-  tm_event_msg_ = 0;
-  _clear_bit(21);
-}
-inline ::google::protobuf::int32 events::tm_event_msg() const {
-  return tm_event_msg_;
-}
-inline void events::set_tm_event_msg(::google::protobuf::int32 value) {
-  _set_bit(21);
-  tm_event_msg_ = value;
-}
-
-// optional uint32 data4 = 23;
-inline bool events::has_data4() const {
-  return _has_bit(22);
-}
-inline void events::clear_data4() {
-  data4_ = 0u;
-  _clear_bit(22);
-}
-inline ::google::protobuf::uint32 events::data4() const {
-  return data4_;
-}
-inline void events::set_data4(::google::protobuf::uint32 value) {
-  _set_bit(22);
-  data4_ = value;
-}
-
-
-}  // namespace dtm
-#endif  // PROTOBUF_dtm_2eevents_2eproto__INCLUDED