You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by jp...@apache.org on 2017/02/21 15:18:55 UTC

[trafficserver] branch master updated (ac79169 -> 2ee7137)

This is an automated email from the ASF dual-hosted git repository.

jpeach pushed a change to branch master
in repository https://git-dual.apache.org/repos/asf/trafficserver.git.

      from  ac79169   Changes debug builds with Intel to just -g
       new  5cf4af4   Fix textBuffer va_args handling.
       new  2ee7137   Rename textBuffer to TextBuffer.

The 2 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "adds" were already present in the repository and have only
been added to this reference.


Summary of changes:
 cmd/traffic_crashlog/procinfo.cc       |  4 ++--
 cmd/traffic_manager/WebOverview.h      |  6 +++---
 cmd/traffic_manager/traffic_manager.cc |  2 +-
 iocore/eventsystem/SocketManager.cc    |  2 +-
 lib/records/P_RecCore.cc               |  6 +++---
 lib/records/P_RecCore.h                |  4 ++--
 lib/records/RecLocal.cc                |  2 +-
 lib/records/RecProcess.cc              |  4 ++--
 lib/ts/Result.h                        |  2 +-
 lib/ts/TextBuffer.cc                   | 36 +++++++++++++++++-----------------
 lib/ts/TextBuffer.h                    | 10 +++++-----
 lib/ts/ink_inet.cc                     |  2 +-
 mgmt/FileManager.cc                    | 24 +++++++++++------------
 mgmt/FileManager.h                     | 16 +++++++--------
 mgmt/MultiFile.cc                      |  6 +++---
 mgmt/MultiFile.h                       |  6 +++---
 mgmt/Rollback.cc                       | 24 +++++++++++------------
 mgmt/Rollback.h                        | 24 +++++++++++------------
 mgmt/api/CoreAPI.cc                    | 14 ++++++-------
 mgmt/cluster/ClusterCom.cc             | 20 +++++++++----------
 mgmt/cluster/ClusterCom.h              |  2 +-
 21 files changed, 108 insertions(+), 108 deletions(-)

-- 
To stop receiving notification emails like this one, please contact
['"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>'].

[trafficserver] 02/02: Rename textBuffer to TextBuffer.

Posted by jp...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jpeach pushed a commit to branch master
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 2ee71379a9a57616ae5b501da04341d08f3e8aca
Author: James Peach <jp...@apache.org>
AuthorDate: Tue Feb 21 07:18:28 2017 -0800

    Rename textBuffer to TextBuffer.
---
 cmd/traffic_crashlog/procinfo.cc       |  4 ++--
 cmd/traffic_manager/WebOverview.h      |  6 +++---
 cmd/traffic_manager/traffic_manager.cc |  2 +-
 iocore/eventsystem/SocketManager.cc    |  2 +-
 lib/records/P_RecCore.cc               |  6 +++---
 lib/records/P_RecCore.h                |  4 ++--
 lib/records/RecLocal.cc                |  2 +-
 lib/records/RecProcess.cc              |  4 ++--
 lib/ts/Result.h                        |  2 +-
 lib/ts/TextBuffer.cc                   | 34 +++++++++++++++++-----------------
 lib/ts/TextBuffer.h                    | 10 +++++-----
 lib/ts/ink_inet.cc                     |  2 +-
 mgmt/FileManager.cc                    | 24 ++++++++++++------------
 mgmt/FileManager.h                     | 16 ++++++++--------
 mgmt/MultiFile.cc                      |  6 +++---
 mgmt/MultiFile.h                       |  6 +++---
 mgmt/Rollback.cc                       | 24 ++++++++++++------------
 mgmt/Rollback.h                        | 24 ++++++++++++------------
 mgmt/api/CoreAPI.cc                    | 14 +++++++-------
 mgmt/cluster/ClusterCom.cc             | 20 ++++++++++----------
 mgmt/cluster/ClusterCom.h              |  2 +-
 21 files changed, 107 insertions(+), 107 deletions(-)

diff --git a/cmd/traffic_crashlog/procinfo.cc b/cmd/traffic_crashlog/procinfo.cc
index aa0658d..a0a96b8 100644
--- a/cmd/traffic_crashlog/procinfo.cc
+++ b/cmd/traffic_crashlog/procinfo.cc
@@ -55,7 +55,7 @@ static bool
 write_procfd_file(const char *filename, const char *label, FILE *fp, const crashlog_target &target)
 {
   ats_scoped_fd fd;
-  textBuffer text(0);
+  TextBuffer text(0);
   fd = procfd_open(target.pid, filename);
   if (fd != -1) {
     text.slurp(fd);
@@ -117,7 +117,7 @@ crashlog_write_procname(FILE *fp, const crashlog_target &target)
 {
   ats_scoped_fd fd;
   ats_scoped_str str;
-  textBuffer text(0);
+  TextBuffer text(0);
 
   fd = procfd_open(target.pid, "comm");
   if (fd != -1) {
diff --git a/cmd/traffic_manager/WebOverview.h b/cmd/traffic_manager/WebOverview.h
index 1d682e9..2cbce7a 100644
--- a/cmd/traffic_manager/WebOverview.h
+++ b/cmd/traffic_manager/WebOverview.h
@@ -118,10 +118,10 @@ private:
   overviewPage(const overviewPage &);
   void addRecord(ClusterPeerInfo *cpi);
   overviewRecord *findNodeByName(const char *nodeName);
-  void addReading(MgmtInt reading, textBuffer *output, int nDigits, const char **gifs, const char **alts);
-  void addLoadBar(textBuffer *output, MgmtInt load);
+  void addReading(MgmtInt reading, TextBuffer *output, int nDigits, const char **gifs, const char **alts);
+  void addLoadBar(TextBuffer *output, MgmtInt load);
   void sortHosts();
-  bool moreInfoButton(const char *submission, textBuffer *output);
+  bool moreInfoButton(const char *submission, TextBuffer *output);
 
   // Private variables
   InkHashTable *nodeRecords;  // container for overviewRecords
diff --git a/cmd/traffic_manager/traffic_manager.cc b/cmd/traffic_manager/traffic_manager.cc
index ce33925..14fd48b 100644
--- a/cmd/traffic_manager/traffic_manager.cc
+++ b/cmd/traffic_manager/traffic_manager.cc
@@ -618,7 +618,7 @@ main(int argc, const char **argv)
   // so we append the outputlog location to the persistent proxy options
   //
   // TS needs them to be able to create BaseLogFiles for each value
-  textBuffer args(1024);
+  TextBuffer args(1024);
 
   if (*bind_stdout) {
     const char *space = args.empty() ? "" : " ";
diff --git a/iocore/eventsystem/SocketManager.cc b/iocore/eventsystem/SocketManager.cc
index 8b4366b..167c1d2 100644
--- a/iocore/eventsystem/SocketManager.cc
+++ b/iocore/eventsystem/SocketManager.cc
@@ -121,7 +121,7 @@ SocketManager::fastopen_supported()
   int value = 0;
 
   if (fd) {
-    textBuffer buffer(16);
+    TextBuffer buffer(16);
 
     buffer.slurp(fd.get());
     value = atoi(buffer.bufPtr());
diff --git a/lib/records/P_RecCore.cc b/lib/records/P_RecCore.cc
index 1ad5200..aac94b2 100644
--- a/lib/records/P_RecCore.cc
+++ b/lib/records/P_RecCore.cc
@@ -627,7 +627,7 @@ RecReadConfigFile(bool inc_version)
 // RecSyncConfigFile
 //-------------------------------------------------------------------------
 RecErrT
-RecSyncConfigToTB(textBuffer *tb, bool *inc_version)
+RecSyncConfigToTB(TextBuffer *tb, bool *inc_version)
 {
   RecErrT err = REC_ERR_FAIL;
 
@@ -679,7 +679,7 @@ RecSyncConfigToTB(textBuffer *tb, bool *inc_version)
     if (sync_to_disk) {
       char b[1024];
 
-      // okay, we're going to write into our textBuffer
+      // okay, we're going to write into our TextBuffer
       err = REC_ERR_OKAY;
       tb->reUse();
 
@@ -931,7 +931,7 @@ RecSetSyncRequired(char *name, bool lock)
 }
 
 RecErrT
-RecWriteConfigFile(textBuffer *tb)
+RecWriteConfigFile(TextBuffer *tb)
 {
 #define TMP_FILENAME_EXT_STR ".tmp"
 #define TMP_FILENAME_EXT_LEN (sizeof(TMP_FILENAME_EXT_STR) - 1)
diff --git a/lib/records/P_RecCore.h b/lib/records/P_RecCore.h
index 4acdf06..bcbbb0e 100644
--- a/lib/records/P_RecCore.h
+++ b/lib/records/P_RecCore.h
@@ -80,8 +80,8 @@ RecErrT RecGetRecord_Xmalloc(const char *name, RecDataT data_type, RecData *data
 RecErrT RecReadStatsFile();
 RecErrT RecSyncStatsFile();
 RecErrT RecReadConfigFile(bool inc_version);
-RecErrT RecWriteConfigFile(textBuffer *tb);
-RecErrT RecSyncConfigToTB(textBuffer *tb, bool *inc_version = nullptr);
+RecErrT RecWriteConfigFile(TextBuffer *tb);
+RecErrT RecSyncConfigToTB(TextBuffer *tb, bool *inc_version = nullptr);
 
 //-------------------------------------------------------------------------
 // Misc
diff --git a/lib/records/RecLocal.cc b/lib/records/RecLocal.cc
index 842ad64..abe31db 100644
--- a/lib/records/RecLocal.cc
+++ b/lib/records/RecLocal.cc
@@ -62,7 +62,7 @@ i_am_the_record_owner(RecT rec_type)
 static void *
 sync_thr(void *data)
 {
-  textBuffer *tb           = new textBuffer(65536);
+  TextBuffer *tb           = new TextBuffer(65536);
   FileManager *configFiles = (FileManager *)data;
 
   while (1) {
diff --git a/lib/records/RecProcess.cc b/lib/records/RecProcess.cc
index 5589909..7f02b6f 100644
--- a/lib/records/RecProcess.cc
+++ b/lib/records/RecProcess.cc
@@ -171,12 +171,12 @@ struct config_update_cont : public Continuation {
 // sync_cont
 //-------------------------------------------------------------------------
 struct sync_cont : public Continuation {
-  textBuffer *m_tb;
+  TextBuffer *m_tb;
 
   sync_cont(ProxyMutex *m) : Continuation(m)
   {
     SET_HANDLER(&sync_cont::sync);
-    m_tb = new textBuffer(65536);
+    m_tb = new TextBuffer(65536);
   }
 
   ~sync_cont()
diff --git a/lib/ts/Result.h b/lib/ts/Result.h
index 4cefbd8..c336acb 100644
--- a/lib/ts/Result.h
+++ b/lib/ts/Result.h
@@ -65,7 +65,7 @@ struct Result {
   }
 
 private:
-  textBuffer buf;
+  TextBuffer buf;
 };
 
 #endif /* RESULT_H_77147E59_67CF_4DD7_A58D_ED3502981E87 */
diff --git a/lib/ts/TextBuffer.cc b/lib/ts/TextBuffer.cc
index f5de8e3..1453c98 100644
--- a/lib/ts/TextBuffer.cc
+++ b/lib/ts/TextBuffer.cc
@@ -34,7 +34,7 @@
  *
  ****************************************************************************/
 
-textBuffer::textBuffer(int size)
+TextBuffer::TextBuffer(int size)
 {
   bufferStart = nullptr;
   nextAdd     = nullptr;
@@ -53,13 +53,13 @@ textBuffer::textBuffer(int size)
   }
 }
 
-textBuffer::~textBuffer()
+TextBuffer::~TextBuffer()
 {
   ats_free(bufferStart);
 }
 
 char *
-textBuffer::release()
+TextBuffer::release()
 {
   char *ret = bufferStart;
 
@@ -69,13 +69,13 @@ textBuffer::release()
   return ret;
 }
 
-// void textBuffer::reUse()
+// void TextBuffer::reUse()
 //
 //   Sets the text buffer for reuse by repositioning the
 //     ptrs to beginning of buffer.  The buffer space is
 //     reused
 void
-textBuffer::reUse()
+TextBuffer::reUse()
 {
   if (bufferStart != nullptr) {
     nextAdd    = bufferStart;
@@ -84,7 +84,7 @@ textBuffer::reUse()
   }
 }
 
-// int textBuffer::copyFrom(void*,int num_bytes)
+// int TextBuffer::copyFrom(void*,int num_bytes)
 //
 //
 //  Copy N bytes (determined by num_bytes) on to the
@@ -93,7 +93,7 @@ textBuffer::reUse()
 //  Returns the number of bytes copies or
 //  -1 if there was insufficient memory
 int
-textBuffer::copyFrom(const void *source, unsigned num_bytes)
+TextBuffer::copyFrom(const void *source, unsigned num_bytes)
 {
   // Get more space if necessary
   if (spaceLeft < num_bytes) {
@@ -111,7 +111,7 @@ textBuffer::copyFrom(const void *source, unsigned num_bytes)
   return num_bytes;
 }
 
-//  textBuffer::enlargeBuffer(int n)
+//  TextBuffer::enlargeBuffer(int n)
 //
 //  Enlarge the buffer so at least at N
 //    bytes are free in the buffer.
@@ -121,7 +121,7 @@ textBuffer::copyFrom(const void *source, unsigned num_bytes)
 //  Returns -1 if insufficient memory,
 //    zero otherwise
 int
-textBuffer::enlargeBuffer(unsigned N)
+TextBuffer::enlargeBuffer(unsigned N)
 {
   unsigned addedSize = 0;
   unsigned newSize   = (currentSize ? currentSize : 1) * 2;
@@ -149,7 +149,7 @@ textBuffer::enlargeBuffer(unsigned N)
   return 0;
 }
 
-// int textBuffer::rawReadFromFile
+// int TextBuffer::rawReadFromFile
 //
 // - Issues a single read command on the file descriptor or handle
 //   passed in and reads in raw data (not assumed to be text, no
@@ -158,7 +158,7 @@ textBuffer::enlargeBuffer(unsigned N)
 //   read() function replaces CR-LF with LF if the file is not
 //   opened in binary mode.
 int
-textBuffer::rawReadFromFile(int fd)
+TextBuffer::rawReadFromFile(int fd)
 {
   int readSize;
 
@@ -186,7 +186,7 @@ textBuffer::rawReadFromFile(int fd)
 
 // Read the entire contents of the given file descriptor.
 void
-textBuffer::slurp(int fd)
+TextBuffer::slurp(int fd)
 {
   int nbytes;
 
@@ -195,13 +195,13 @@ textBuffer::slurp(int fd)
   } while (nbytes > 0);
 }
 
-// int textBuffer::readFromFD(int fd)
+// int TextBuffer::readFromFD(int fd)
 //
 // Issues a single read command on the file
 // descritor passed in.  Attempts to read a minimum of
 // 512 bytes from file descriptor passed.
 int
-textBuffer::readFromFD(int fd)
+TextBuffer::readFromFD(int fd)
 {
   int readSize;
 
@@ -230,7 +230,7 @@ textBuffer::readFromFD(int fd)
 }
 
 void
-textBuffer::vformat(const char *fmt, va_list ap)
+TextBuffer::vformat(const char *fmt, va_list ap)
 {
   for (bool done = false; !done;) {
     int num;
@@ -260,7 +260,7 @@ textBuffer::vformat(const char *fmt, va_list ap)
 }
 
 void
-textBuffer::format(const char *fmt, ...)
+TextBuffer::format(const char *fmt, ...)
 {
   va_list ap;
 
@@ -270,7 +270,7 @@ textBuffer::format(const char *fmt, ...)
 }
 
 void
-textBuffer::chomp()
+TextBuffer::chomp()
 {
   while ((nextAdd > bufferStart) && (nextAdd[-1] == '\n')) {
     --nextAdd;
diff --git a/lib/ts/TextBuffer.h b/lib/ts/TextBuffer.h
index 5e96cd0..127ae0a 100644
--- a/lib/ts/TextBuffer.h
+++ b/lib/ts/TextBuffer.h
@@ -37,19 +37,19 @@
 
 #include <stdarg.h>
 
-class textBuffer
+class TextBuffer
 {
 public:
-  textBuffer() {}
-  textBuffer(const textBuffer &rhs)
+  TextBuffer() {}
+  TextBuffer(const TextBuffer &rhs)
   {
     if (!rhs.empty()) {
       copyFrom(rhs.bufPtr(), rhs.spaceUsed());
     }
   }
 
-  textBuffer(int size);
-  ~textBuffer();
+  TextBuffer(int size);
+  ~TextBuffer();
 
   int rawReadFromFile(int fd);
   int readFromFD(int fd);
diff --git a/lib/ts/ink_inet.cc b/lib/ts/ink_inet.cc
index 79dadf1..16f67dd 100644
--- a/lib/ts/ink_inet.cc
+++ b/lib/ts/ink_inet.cc
@@ -621,7 +621,7 @@ ats_tcp_somaxconn()
 
   fd = open("/proc/sys/net/ipv4/tcp_max_syn_backlog", O_RDONLY);
   if (fd != -1) {
-    textBuffer text(0);
+    TextBuffer text(0);
     text.slurp(fd);
     if (!text.empty()) {
       value = strtoul(text.bufPtr(), nullptr, 10);
diff --git a/mgmt/FileManager.cc b/mgmt/FileManager.cc
index 656a16f..c906520 100644
--- a/mgmt/FileManager.cc
+++ b/mgmt/FileManager.cc
@@ -193,16 +193,16 @@ FileManager::fileChanged(const char *fileName, bool incVersion)
   ink_mutex_release(&cbListLock);
 }
 
-// textBuffer* FileManager::filesManaged()
+// TextBuffer* FileManager::filesManaged()
 //
 //  Returns a comma separated list of all files currently being
 //    managed by this object
 //
 //  CALLEE DELETES the returned space
-textBuffer *
+TextBuffer *
 FileManager::filesManaged()
 {
-  textBuffer *result = new textBuffer(1024);
+  TextBuffer *result = new TextBuffer(1024);
   const char *currentName;
   const char separator[] = "\n";
   Rollback *rb;
@@ -315,7 +315,7 @@ FileManager::restoreSnap(const char *snapName, const char *snapDir)
   SnapResult result = SNAP_OK;
   char *snapPath;
   char *filePath = nullptr;
-  textBuffer storage(2048);
+  TextBuffer storage(2048);
 
   snapPath = newPathString(snapDir, snapName);
 
@@ -496,13 +496,13 @@ FileManager::takeSnap(const char *snapName, const char *snapDir)
 }
 
 //
-//  SnapResult FileManager::readFile(const char* filePath, textBuffer* contents)
+//  SnapResult FileManager::readFile(const char* filePath, TextBuffer* contents)
 //
-//  Reads the specified file into the textBuffer.  Returns SNAP_OK if
+//  Reads the specified file into the TextBuffer.  Returns SNAP_OK if
 //    the file was successfully read and an error code otherwise
 //
 SnapResult
-FileManager::readFile(const char *filePath, textBuffer *contents)
+FileManager::readFile(const char *filePath, TextBuffer *contents)
 {
   int diskFD;
   int readResult;
@@ -541,7 +541,7 @@ FileManager::copyFile(Rollback *rb, const char *snapPath)
   const char *fileName;
   char *filePath;
   int diskFD;
-  textBuffer *copyBuf;
+  TextBuffer *copyBuf;
   SnapResult result;
 
   fileName = rb->getBaseName();
@@ -691,13 +691,13 @@ FileManager::isConfigStale()
   return stale;
 }
 
-// void FileManager::displaySnapPage(textBuffer* output, httpResponse& answerHdr)
+// void FileManager::displaySnapPage(TextBuffer* output, httpResponse& answerHdr)
 //
 //  Generates an HTML page with the add form and the list
 //    of current snapshots
 //
 void
-FileManager::displaySnapOption(textBuffer *output)
+FileManager::displaySnapOption(TextBuffer *output)
 {
   ExpandingArray snap_list(25, true);
   SnapResult snap_result;
@@ -712,14 +712,14 @@ FileManager::displaySnapOption(textBuffer *output)
   }
 }
 
-// void FileManger::createSelect(char* formVar, textBuffer* output, ExpandingArray*)
+// void FileManger::createSelect(char* formVar, TextBuffer* output, ExpandingArray*)
 //
 //  Creats a form with a select list.  The select options come
 //    from the expanding array.  Action is the value for the hidden input
 //    tag with name action
 //
 void
-FileManager::createSelect(char *action, textBuffer *output, ExpandingArray *options)
+FileManager::createSelect(char *action, TextBuffer *output, ExpandingArray *options)
 {
   const char formOpen[]     = "<form method=POST action=\"/configure/snap_action.html\">\n<select name=snap>\n";
   const char formEnd[]      = "</form>";
diff --git a/mgmt/FileManager.h b/mgmt/FileManager.h
index cf2b376..44e3563 100644
--- a/mgmt/FileManager.h
+++ b/mgmt/FileManager.h
@@ -95,7 +95,7 @@ class ExpandingArray;
 //  fileChanged(const char* fileName) - called by Rollback objects
 //       when their contents change.  Triggers callbacks to FileCallbackFuncs
 //
-//  filesManaged() - returns a textBuffer that contains a new line separated
+//  filesManaged() - returns a TextBuffer that contains a new line separated
 //       list of call files being managed by the FileManager.  CALLEE
 //       is responsible for deleting the returned object
 //
@@ -120,7 +120,7 @@ public:
   bool getRollbackObj(const char *fileName, Rollback **rbPtr);
   void registerCallback(FileCallbackFunc func);
   void fileChanged(const char *fileName, bool incVersion);
-  textBuffer *filesManaged();
+  TextBuffer *filesManaged();
   void rereadConfig();
   bool isConfigStale();
   // SnapResult takeSnap(const char* snapName);
@@ -129,7 +129,7 @@ public:
   SnapResult restoreSnap(const char *snapName, const char *snapDir);
   // SnapResult removeSnap(const char* snapName);
   SnapResult removeSnap(const char *snapName, const char *snapDir);
-  void displaySnapOption(textBuffer *output);
+  void displaySnapOption(TextBuffer *output);
   SnapResult WalkSnaps(ExpandingArray *snapList);
   void configFileChild(const char *parent, const char *child, unsigned int options);
 
@@ -141,12 +141,12 @@ private:
   InkHashTable *bindings;
   // InkHashTable* g_snapshot_directory_ht;
   SnapResult copyFile(Rollback *rb, const char *snapPath);
-  SnapResult readFile(const char *filePath, textBuffer *contents);
+  SnapResult readFile(const char *filePath, TextBuffer *contents);
   void abortRestore(const char *abortTo);
-  void createSelect(char *action, textBuffer *output, ExpandingArray *options);
-  void snapErrorResponse(char *action, SnapResult error, textBuffer *output);
-  void snapSuccessResponse(char *action, textBuffer *output);
-  void generateRestoreConfirm(char *snapName, textBuffer *output);
+  void createSelect(char *action, TextBuffer *output, ExpandingArray *options);
+  void snapErrorResponse(char *action, SnapResult error, TextBuffer *output);
+  void snapSuccessResponse(char *action, TextBuffer *output);
+  void generateRestoreConfirm(char *snapName, TextBuffer *output);
   bool checkValidName(const char *name);
   const char *getParentFileName(const char *fileName);
   void addFileHelper(const char *fileName, bool root_access_needed, Rollback *parentRollback, unsigned flags = 0);
diff --git a/mgmt/MultiFile.cc b/mgmt/MultiFile.cc
index e048c0a..a8b69e4 100644
--- a/mgmt/MultiFile.cc
+++ b/mgmt/MultiFile.cc
@@ -50,12 +50,12 @@ MultiFile::MultiFile()
   dirDescript = nullptr;
 }
 
-// void MultiFile::addTableEntries(ExpandingArray* fileList, textBuffer* output)
+// void MultiFile::addTableEntries(ExpandingArray* fileList, TextBuffer* output)
 //
 //   Adds table entries to output from the result of WalkFiles
 //
 void
-MultiFile::addTableEntries(ExpandingArray *fileList, textBuffer *output)
+MultiFile::addTableEntries(ExpandingArray *fileList, TextBuffer *output)
 {
   int numFiles = fileList->getNumEntries();
   fileEntry *current;
@@ -152,7 +152,7 @@ MultiFile::isManaged(const char *fileName)
 }
 
 void
-MultiFile::addSelectOptions(textBuffer *output, ExpandingArray *options)
+MultiFile::addSelectOptions(TextBuffer *output, ExpandingArray *options)
 {
   const char selectEnd[]  = "</select>\n";
   const char option[]     = "\t<option value='";
diff --git a/mgmt/MultiFile.h b/mgmt/MultiFile.h
index bfc3e6e..706cc9a 100644
--- a/mgmt/MultiFile.h
+++ b/mgmt/MultiFile.h
@@ -33,7 +33,7 @@
  ****************************************************************************/
 
 class ExpandingArray;
-class textBuffer;
+class TextBuffer;
 
 #if defined(NAME_MAX)
 #define FILE_NAME_MAX NAME_MAX
@@ -69,10 +69,10 @@ public:
 
 protected:
   MFresult WalkFiles(ExpandingArray *fileList);
-  void addTableEntries(ExpandingArray *fileList, textBuffer *output);
+  void addTableEntries(ExpandingArray *fileList, TextBuffer *output);
   char *newPathString(const char *s1, const char *s2);
   bool isManaged(const char *fileName);
-  void addSelectOptions(textBuffer *output, ExpandingArray *options);
+  void addSelectOptions(TextBuffer *output, ExpandingArray *options);
   char *managedDir;
   const char *dirDescript;
 };
diff --git a/mgmt/Rollback.cc b/mgmt/Rollback.cc
index 31d3f75..5e7398f 100644
--- a/mgmt/Rollback.cc
+++ b/mgmt/Rollback.cc
@@ -174,7 +174,7 @@ Rollback::Rollback(const char *fileName_, bool root_access_needed_, Rollback *pa
 
     // Make sure that we have a backup of the file
     if (highestSeen == 0) {
-      textBuffer *version0 = nullptr;
+      TextBuffer *version0 = nullptr;
       char failStr[]       = "[Rollback::Rollback] Automatic Roll of Version 1 failed: %s";
       if (getVersion_ml(ACTIVE_VERSION, &version0) != OK_ROLLBACK) {
         mgmt_log(failStr, fileName);
@@ -316,7 +316,7 @@ Rollback::closeFile(int fd, bool callSync)
 }
 
 RollBackCodes
-Rollback::updateVersion(textBuffer *buf, version_t basedOn, version_t newVersion, bool notifyChange, bool incVersion)
+Rollback::updateVersion(TextBuffer *buf, version_t basedOn, version_t newVersion, bool notifyChange, bool incVersion)
 {
   RollBackCodes returnCode;
 
@@ -328,7 +328,7 @@ Rollback::updateVersion(textBuffer *buf, version_t basedOn, version_t newVersion
 }
 
 RollBackCodes
-Rollback::updateVersion_ml(textBuffer *buf, version_t basedOn, version_t newVersion, bool notifyChange, bool incVersion)
+Rollback::updateVersion_ml(TextBuffer *buf, version_t basedOn, version_t newVersion, bool notifyChange, bool incVersion)
 {
   RollBackCodes returnCode;
 
@@ -342,7 +342,7 @@ Rollback::updateVersion_ml(textBuffer *buf, version_t basedOn, version_t newVers
 }
 
 RollBackCodes
-Rollback::forceUpdate(textBuffer *buf, version_t newVersion)
+Rollback::forceUpdate(TextBuffer *buf, version_t newVersion)
 {
   RollBackCodes r;
 
@@ -354,7 +354,7 @@ Rollback::forceUpdate(textBuffer *buf, version_t newVersion)
 }
 
 RollBackCodes
-Rollback::forceUpdate_ml(textBuffer *buf, version_t newVersion)
+Rollback::forceUpdate_ml(TextBuffer *buf, version_t newVersion)
 {
   return this->internalUpdate(buf, newVersion);
 }
@@ -364,7 +364,7 @@ Rollback::forceUpdate_ml(textBuffer *buf, version_t newVersion)
 //  Creates a version from buf.  Callee must be holding the lock
 //
 RollBackCodes
-Rollback::internalUpdate(textBuffer *buf, version_t newVersion, bool notifyChange, bool incVersion)
+Rollback::internalUpdate(TextBuffer *buf, version_t newVersion, bool notifyChange, bool incVersion)
 {
   RollBackCodes returnCode;
   char *activeVersion;
@@ -505,7 +505,7 @@ UPDATE_CLEANUP:
 }
 
 RollBackCodes
-Rollback::getVersion(version_t version, textBuffer **buffer)
+Rollback::getVersion(version_t version, TextBuffer **buffer)
 {
   RollBackCodes r;
 
@@ -518,13 +518,13 @@ Rollback::getVersion(version_t version, textBuffer **buffer)
 
 // CALLEE DELETES STORAGE
 RollBackCodes
-Rollback::getVersion_ml(version_t version, textBuffer **buffer)
+Rollback::getVersion_ml(version_t version, TextBuffer **buffer)
 {
   int diskFD;               // file descriptor for version of the file we are fetching
   RollBackCodes returnCode; // our eventual return value
   struct stat fileInfo;     // Info from fstat
   int readResult;           // return val of (indirect) read calls
-  textBuffer *newBuffer;    // return buffer
+  TextBuffer *newBuffer;    // return buffer
 
   *buffer = nullptr;
 
@@ -544,7 +544,7 @@ Rollback::getVersion_ml(version_t version, textBuffer **buffer)
     goto GET_CLEANUP;
   }
   // Create a textbuffer of the
-  newBuffer = new textBuffer(fileInfo.st_size + 1);
+  newBuffer = new TextBuffer(fileInfo.st_size + 1);
 
   do {
     readResult = newBuffer->readFromFD(diskFD);
@@ -602,7 +602,7 @@ RollBackCodes
 Rollback::revertToVersion_ml(version_t version)
 {
   RollBackCodes returnCode;
-  textBuffer *revertTo;
+  TextBuffer *revertTo;
 
   returnCode = this->getVersion_ml(version, &revertTo);
   if (returnCode != OK_ROLLBACK) {
@@ -891,7 +891,7 @@ Rollback::checkForUserUpdate(RollBackCheckType how)
 
   // Variables to roll the current version
   version_t currentVersion_local;
-  textBuffer *buf;
+  TextBuffer *buf;
   RollBackCodes r;
 
   ink_mutex_acquire(&fileAccessLock);
diff --git a/mgmt/Rollback.h b/mgmt/Rollback.h
index 6aefdb2..de3f18b 100644
--- a/mgmt/Rollback.h
+++ b/mgmt/Rollback.h
@@ -92,17 +92,17 @@ struct versionInfo {
 //  revertToVersion(version_t) - rolls the active version to a new file
 //    The specified version of the file is copied to the active version
 //
-//  getVersion(version_t version, textBuffer** buffer, version_t) -
-//    creates a new textBuffer that contains the contents of the specified
+//  getVersion(version_t version, TextBuffer** buffer, version_t) -
+//    creates a new TextBuffer that contains the contents of the specified
 //    version.  CALLEE MUST DELETE the buffer
 //
-//  updateVersion(textBuffer* buf, version_t basedOn) - checks to
+//  updateVersion(TextBuffer* buf, version_t basedOn) - checks to
 //    if basedOn is the current version.  If it is not, the update
 //    rejected.  If it is current, the active file is versioned and
 //    the contents of buf become the new active file. newVersion tells us what
 //    the new version number should be.  -1 means the next in sequence
 //
-//  forceUpdate(textBuffer* buf, version_t) - Does not check is the new version
+//  forceUpdate(TextBuffer* buf, version_t) - Does not check is the new version
 //    is based on the current version, which can lead to data loss.  versions
 //    the active file and places the contents of buf into the active file
 //
@@ -149,7 +149,7 @@ struct versionInfo {
 //  createPathStr(version_t) - creates a string to the specified
 //    version of the file.  CALLEE DELETES storage
 //
-//  internalUpdate(textBuffer*, version_t) - does the really work of the
+//  internalUpdate(TextBuffer*, version_t) - does the really work of the
 //    public update functions.  newVersion tells us what the new
 //    version number should be.  -1 means the next in sequence
 
@@ -173,10 +173,10 @@ public:
   };
   RollBackCodes removeVersion_ml(version_t version);
   RollBackCodes revertToVersion_ml(version_t version);
-  RollBackCodes getVersion_ml(version_t version, textBuffer **buffer);
-  RollBackCodes updateVersion_ml(textBuffer *buf, version_t basedOn, version_t newVersion = -1, bool notifyChange = true,
+  RollBackCodes getVersion_ml(version_t version, TextBuffer **buffer);
+  RollBackCodes updateVersion_ml(TextBuffer *buf, version_t basedOn, version_t newVersion = -1, bool notifyChange = true,
                                  bool incVersion = true);
-  RollBackCodes forceUpdate_ml(textBuffer *buf, version_t newVersion = -1);
+  RollBackCodes forceUpdate_ml(TextBuffer *buf, version_t newVersion = -1);
   version_t findVersions_ml(ExpandingArray *listNames);
   version_t findVersions_ml(Queue<versionInfo> &q);
   time_t versionTimeStamp_ml(version_t version);
@@ -186,10 +186,10 @@ public:
   bool checkForUserUpdate(RollBackCheckType);
   RollBackCodes removeVersion(version_t version);
   RollBackCodes revertToVersion(version_t version);
-  RollBackCodes getVersion(version_t version, textBuffer **buffer);
-  RollBackCodes updateVersion(textBuffer *buf, version_t basedOn, version_t newVersion = -1, bool notifyChange = true,
+  RollBackCodes getVersion(version_t version, TextBuffer **buffer);
+  RollBackCodes updateVersion(TextBuffer *buf, version_t basedOn, version_t newVersion = -1, bool notifyChange = true,
                               bool incVersion = true);
-  RollBackCodes forceUpdate(textBuffer *buf, version_t newVersion = -1);
+  RollBackCodes forceUpdate(TextBuffer *buf, version_t newVersion = -1);
   version_t findVersions(ExpandingArray *);
   time_t versionTimeStamp(version_t version);
   int statVersion(version_t, struct stat *buf);
@@ -243,7 +243,7 @@ private:
   int closeFile(int fd, bool callSync);
   int statFile(version_t version, struct stat *buf);
   char *createPathStr(version_t version);
-  RollBackCodes internalUpdate(textBuffer *buf, version_t newVersion, bool notifyChange = true, bool incVersion = true);
+  RollBackCodes internalUpdate(TextBuffer *buf, version_t newVersion, bool notifyChange = true, bool incVersion = true);
   ink_mutex fileAccessLock;
   char *fileName;
   char *fileBaseName;
diff --git a/mgmt/api/CoreAPI.cc b/mgmt/api/CoreAPI.cc
index fe99a95..de8f934 100644
--- a/mgmt/api/CoreAPI.cc
+++ b/mgmt/api/CoreAPI.cc
@@ -253,7 +253,7 @@ done:
 }
 
 static void
-backtrace_for_thread(pid_t threadid, textBuffer &text)
+backtrace_for_thread(pid_t threadid, TextBuffer &text)
 {
   int status;
   unw_addr_space_t addr_space = NULL;
@@ -337,7 +337,7 @@ ServerBacktrace(unsigned /* options */, char **trace)
   // traceable without privilege because the process credentials do not match.
   ElevateAccess access(ElevateAccess::TRACE_PRIVILEGE);
   threadlist threads(threads_for_process(lmgmt->watched_process_pid));
-  textBuffer text(0);
+  TextBuffer text(0);
 
   Debug("backtrace", "tracing %zd threads for traffic_server PID %ld", threads.count(), (long)lmgmt->watched_process_pid);
 
@@ -723,7 +723,7 @@ ReadFile(TSFileNameT file, char **text, int *size, int *version)
   const char *fname;
   Rollback *file_rb;
   int ret, old_file_len;
-  textBuffer *old_file_content;
+  TextBuffer *old_file_content;
   char *old_file_lines;
   version_t ver;
 
@@ -747,10 +747,10 @@ ReadFile(TSFileNameT file, char **text, int *size, int *version)
   old_file_lines = old_file_content->bufPtr();
   old_file_len   = strlen(old_file_lines);
 
-  *text = ats_strdup(old_file_lines); // make copy before deleting textBuffer
+  *text = ats_strdup(old_file_lines); // make copy before deleting TextBuffer
   *size = old_file_len;
 
-  delete old_file_content; // delete textBuffer
+  delete old_file_content; // delete TextBuffer
 
   return TS_ERR_OKAY;
 }
@@ -772,7 +772,7 @@ WriteFile(TSFileNameT file, const char *text, int size, int version)
 {
   const char *fname;
   Rollback *file_rb;
-  textBuffer *file_content;
+  TextBuffer *file_content;
   int ret;
   version_t ver;
 
@@ -799,7 +799,7 @@ WriteFile(TSFileNameT file, const char *text, int size, int version)
     }
   }
   // use rollback object to update file with new content
-  file_content = new textBuffer(size + 1);
+  file_content = new TextBuffer(size + 1);
   ret          = file_content->copyFrom(text, size);
   if (ret < 0) {
     delete file_content;
diff --git a/mgmt/cluster/ClusterCom.cc b/mgmt/cluster/ClusterCom.cc
index 7755927..c5c21e0 100644
--- a/mgmt/cluster/ClusterCom.cc
+++ b/mgmt/cluster/ClusterCom.cc
@@ -259,7 +259,7 @@ drainIncomingChannel(void *arg)
           bool stat = false;
           char fname[1024];
           version_t ver;
-          textBuffer *buff = nullptr;
+          TextBuffer *buff = nullptr;
           Rollback *rb;
 
           /* Get the file and blast it back */
@@ -475,7 +475,7 @@ ClusterCom::checkPeers(time_t *ticker)
   if ((t - *ticker) > 5) {
     int num_peers = 0;
     long idle_since;
-    textBuffer *buff;
+    TextBuffer *buff;
 
     Debug("ccom", "MultiCast Messages received: %d", MultiCastMessages);
 
@@ -517,7 +517,7 @@ ClusterCom::checkPeers(time_t *ticker)
     }
 
     /* Create the base for the cluster file(inserting header comment) */
-    buff = new textBuffer(strlen(CLUSTER_CONFIG_FILE_BLURB) + 1024);
+    buff = new TextBuffer(strlen(CLUSTER_CONFIG_FILE_BLURB) + 1024);
     buff->copyFrom(CLUSTER_CONFIG_FILE_BLURB, strlen(CLUSTER_CONFIG_FILE_BLURB));
 
     if (cluster_type == FULL_CLUSTER) {
@@ -1054,7 +1054,7 @@ extract_locals(MgmtHashTable *local_ht, char *record_buffer)
 }
 
 bool
-insert_locals(textBuffer *rec_cfg_new, textBuffer *rec_cfg, MgmtHashTable *local_ht)
+insert_locals(TextBuffer *rec_cfg_new, TextBuffer *rec_cfg, MgmtHashTable *local_ht)
 {
   char *p, *q, *line, *name;
   bool eof;
@@ -1156,7 +1156,7 @@ ClusterCom::handleMultiCastFilePacket(char *last, char *ip)
                             * cluster anymore.
                             */
         char message[1024];
-        textBuffer *reply = new textBuffer(2048); /* Start with 2k file size */
+        TextBuffer *reply = new TextBuffer(2048); /* Start with 2k file size */
         snprintf(message, sizeof(message), "file: %s %d", file, ver);
 
         /* Send request, read response, write new file. */
@@ -1173,9 +1173,9 @@ ClusterCom::handleMultiCastFilePacket(char *last, char *ip)
         // records; store our LOCAL records in a hash-table, and then
         // merge our LOCALs into the newly acquired remote config.
         if (!file_update_failure && (strcmp(file, "records.config") == 0)) {
-          textBuffer *our_rec_cfg;
+          TextBuffer *our_rec_cfg;
           char *our_rec_cfg_cp;
-          textBuffer *reply_new;
+          TextBuffer *reply_new;
           MgmtHashTable *our_locals_ht;
 
           if (rb->getVersion(our_ver, &our_rec_cfg) != OK_ROLLBACK) {
@@ -1184,7 +1184,7 @@ ClusterCom::handleMultiCastFilePacket(char *last, char *ip)
             our_locals_ht  = new MgmtHashTable("our_locals_ht", true, InkHashTableKeyType_String);
             our_rec_cfg_cp = ats_strdup(our_rec_cfg->bufPtr());
             extract_locals(our_locals_ht, our_rec_cfg_cp);
-            reply_new = new textBuffer(reply->spaceUsed());
+            reply_new = new TextBuffer(reply->spaceUsed());
             if (!insert_locals(reply_new, reply, our_locals_ht)) {
               file_update_failure = true;
               delete reply_new;
@@ -1526,7 +1526,7 @@ ClusterCom::constructSharedFilePacket(char *message, int max)
   int running_sum = 0;
   char tmp[1024], *files, *line, *last;
   struct in_addr resolved_addr;
-  textBuffer *buff;
+  TextBuffer *buff;
 
   /* Insert the standard packet header */
   resolved_addr.s_addr = our_ip;
@@ -1973,7 +1973,7 @@ ClusterCom::sendReliableMessage(unsigned long addr, char *buf, int len, char *re
  *   Used to send a string across the reliable fd.
  */
 bool
-ClusterCom::sendReliableMessageReadTillClose(unsigned long addr, char *buf, int len, textBuffer *reply)
+ClusterCom::sendReliableMessageReadTillClose(unsigned long addr, char *buf, int len, TextBuffer *reply)
 {
   int fd, cport, res;
   char string_addr[80], tmp_reply[1024];
diff --git a/mgmt/cluster/ClusterCom.h b/mgmt/cluster/ClusterCom.h
index c0ecc86..55f2b26 100644
--- a/mgmt/cluster/ClusterCom.h
+++ b/mgmt/cluster/ClusterCom.h
@@ -126,7 +126,7 @@ public:
 
   bool rl_sendReliableMessage(unsigned long addr, const char *buf, int len);
   bool sendReliableMessage(unsigned long addr, char *buf, int len, char *reply, int len2, bool take_lock);
-  bool sendReliableMessageReadTillClose(unsigned long addr, char *buf, int len, textBuffer *reply);
+  bool sendReliableMessageReadTillClose(unsigned long addr, char *buf, int len, TextBuffer *reply);
 
   int receiveIncomingMessage(char *buf, int max);
 

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 01/02: Fix textBuffer va_args handling.

Posted by jp...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

jpeach pushed a commit to branch master
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 5cf4af4c7417c97ca2398f96987b7fcf4f5b345a
Author: James Peach <jp...@apache.org>
AuthorDate: Tue Feb 21 07:08:36 2017 -0800

    Fix textBuffer va_args handling.
---
 lib/ts/TextBuffer.cc | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)

diff --git a/lib/ts/TextBuffer.cc b/lib/ts/TextBuffer.cc
index 0811e77..f5de8e3 100644
--- a/lib/ts/TextBuffer.cc
+++ b/lib/ts/TextBuffer.cc
@@ -242,7 +242,7 @@ textBuffer::vformat(const char *fmt, va_list ap)
 
     num = vsnprintf(this->nextAdd, this->spaceLeft, fmt, args);
 
-    va_end(ap);
+    va_end(args);
 
     if ((unsigned)num < this->spaceLeft) {
       // We had enough space to format including the NUL. Since the returned character

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.