You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by ig...@apache.org on 2010/11/06 07:30:02 UTC

svn commit: r1031963 [7/13] - in /trafficserver/site/branches/ats-cms: content/docs/trunk/sdk/ templates/

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIOBufferWrite.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIOBufferWrite.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIOBufferWrite.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIOBufferWrite.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,87 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKIOBufferWaterMarkSet) - INKIOBufferWaterMarkSet
+Management Interface Functions -
+[Next](ManagementInterfaceFunctions)
+### INKIOBufferWrite
+
+Appends the specified number of bytes from a particular buffer to
+the IO buffer.
+
+**Prototype**
+  ~ `int INKIOBufferWrite (INKIOBuffer               <em class="replaceable"><code>bufp`,
+    const char *`*buf`*, int *`len`*)
+
+**Arguments**
+  ~ `INKIOBuffer` `<em class="replaceable"><code>bufp` is the
+    target IOBuffer that receives the data.
+
+    `const char <em class="replaceable"><code>*buf` is the buffer that
+    contains the data.
+
+    `int <em class="replaceable"><code>len` is the length of the data
+    to write.
+
+**Description**
+  ~ This function appends data from
+    `<em class="replaceable"><code>*buf` to IOBuffer
+    `<em class="replaceable"><code>bufp`; the length of data being
+    appended is specified in `<em class="replaceable"><code>len`. The
+    returned value is the actual length of data being appended.
+
+**Example**
+  ~ `INKIOBufferWrite` offers the same functionality as the
+    deprecated functions `INKIOBufferAppend`, `INKIOBufferDataCreate`,
+    and `INKIOBufferBlockCreate`. To append the content of a buffer
+    `<em class="replaceable"><code>buf` of size
+    `<em class="replaceable"><code>len` into an `IOBuffer`, we
+    recommend using `INKIOBufferWrite`. It has the following
+    prototype:
+
+        int INKIOBufferWrite (INKIOBuffer bufp, const char *buf, int len); 
+        
+        The equivalent of this API in SDK2.0 is the following snippet of code: 
+         INKIOBufferBlock block; 
+         int avail, ndone, ntodo, towrite; 
+         char *ptr_block; 
+        
+         ndone = 0; 
+         ntodo = len; 
+         while (ntodo > 0) { 
+              /* INKIOBufferStart allocates more blocks if required */ 
+              block = INKIOBufferStart(bufp); 
+              ptr_block = INKIOBufferBlockWriteStart (block, &avail); 
+              towrite = min(ntodo, avail); 
+              memcpy (ptr_block, buf+ndone, towrite); 
+              INKIOBufferProduce(bufp, towrite); 
+              ntodo -= towrite; 
+              ndone += towrite; 
+        } 
+
+   
+**Returns**
+  ~ The length of data copied if the API call is successful.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIsDebugTagSet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIsDebugTagSet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIsDebugTagSet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKIsDebugTagSet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,52 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](DebuggingFunctions) - Debugging Functions
+INKError - [Next](INKError)
+### INKIsDebugTagSet
+
+Indicates if a particular debug tag is set.
+
+**Prototype**
+  ~ `void INKError (const char <em class="replaceable"><code>*fmt,               ...`)
+
+**Arguments**
+  ~ `<em class="replaceable"><code>fmt` is the `printf` format
+    description.
+
+    `...` is the argument for the format description.
+
+**Description**
+  ~ Since it is sometimes useful to log messages when errors occur,
+    Traffic Server provides a global error log file for this purpose.
+    The function `INKError` is the API interface to this error log.
+    `INKError` is similar to `printf`, except that `INKError` writes
+    output to the Traffic Server error log instead of writing the
+    output to the C standard output. One advantage of `INKError` over
+    `printf` is that each call is atomically placed into the error log
+    and not garbled with other error entries (this is not an issue in
+    single-threaded programs, but is a definite nuisance in
+    multi-threaded programs).
+
+**Example**
+  ~     INKError ("couldn't retrieve client request header\n");
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMBufferDestroy.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMBufferDestroy.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMBufferDestroy.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMBufferDestroy.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,42 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](MarshallBuffersFunctions) - Marshal Buffers:
+INKMBufferCreate
+HTTP Header Functions - [Next](HTTPHeaderFunctions)
+### INKMBufferDestroy
+
+Destroys a marshal buffer.
+
+**Prototype**
+  ~ `void INKMBufferDestroy (INKMBuffer               <em class="replaceable"><code>bufp`)
+
+**Arguments**
+  ~ `<em class="replaceable"><code>bufp` is the marshal buffer to
+    be destroyed.
+
+**Description**
+  ~ Ignores the reference count and destroys the marshal buffer
+    `<em class="replaceable"><code>bufp`. The internal data buffer
+    associated with the marshal buffer is also destroyed (if the
+    marshal buffer allocated it).
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtFloatGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtFloatGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtFloatGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtFloatGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,50 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](TEConfigReadFunctions) - Configuration Read Functions:
+INKMgmtCounterGet
+INKMgmtIntGet - [Next](INKMgmtIntGet)
+### INKMgmtFloatGet
+
+Gets a `records.config` variable of type `float`.
+
+**Prototype**
+  ~ `int INKMgmtFloatGet (const char *<i class="replaceable">var_name</i>,       INKMgmtFloat *<i class="replaceable">result</i>)`
+
+**Arguments**
+  ~ `<i>var_name </i>` is the name of the variable you want from
+    the `records.config` file.
+
+    `<i>result </i>` is a pointer to the value of the variable, which
+    is of type `INKMgmtFloat`.
+
+**Description**
+  ~ `INKMgmtFloatGet` obtains the value of the specified
+    `records.config` variable of type `float`, and then stores the
+    value in `result`.
+
+**Returns**
+  ~ If `INKMgmtFloatGet` cannot get the variable, then it returns
+    zero.
+
+  ~ If it is successful, then a nonzero value is returned.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtIntGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtIntGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtIntGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtIntGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,62 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKMgmtFloatGet) - INKMgmtFloatGet
+INKMgmtStringGet - [Next](INKMgmtStringGet)
+### INKMgmtIntGet
+
+Get a `records.config` variable of type `int`.
+
+**Prototype**
+  ~ `int INKMgmtIntGet (const char *<i class="replaceable">var_name</i>, INKMgmtInt       *<i class="replaceable">result</i>)`
+
+**Arguments**
+  ~ `<i>var_name </i>` is the name of the variable you want from
+    the `records.config` file.
+
+    `<i>result </i>` is a pointer to the variable's value, which is of
+    type `INKMgmtInt`.
+
+**Description**
+  ~ `INKMgmtIntGet` obtains the value of the specified
+    `records.config` variable of type `int`, and then stores the value
+    in `result`.
+
+**Example**
+  ~ The following code fragment does something if keepalive is
+    enabled on Traffic Server:
+
+        INKMgmtInt result;
+           if (INKMgmtIntGet("proxy.config.http.keep_alive_enabled", &result)) {
+           if (result){
+           // keepalive is enabled, do something
+           }
+        }
+        else INKError ("could not retrieve value\n");
+
+   
+**Returns**
+  ~ If `INKMgmtIntGet` cannot get the variable, then zero is
+    returned.
+
+  ~ If it is successful, then it returns a nonzero value.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtStringGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtStringGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtStringGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMgmtStringGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,53 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKMgmtIntGet) - INKMgmtIntGet
+Coupled Statistics Functions -
+[Next](StatisticsFunctions)
+### INKMgmtStringGet
+
+Get a `records.config` variable of type `String`.
+
+**Prototype**
+  ~ `int INKMgmtStringGet (const char *<i>var_name</i>,               INKMgmtString *<i>result</i>)`
+
+**Arguments**
+  ~ `<i>var_name </i>` is the name of the variable you want from
+    the `records.config` file.
+
+    `<i>result </i>` is a pointer to the value of the variable. This
+    value is of type `INKMgmtString`.
+
+**Description**
+  ~ `INKMgmtStringGet` obtains the value of the specified
+    `records.config` variable of type `String`, and then stores the
+    value in `result`.
+
+    When it's finished with the result, your plugin must deallocate the
+    result string with a call to `INKfree`.
+
+**Returns**
+  ~ If `INKMgmtStringGet` cannot get the variable, then it returns
+    zero.
+
+  ~ If it is successful, then a nonzero value is returned.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLock.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLock.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLock.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLock.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,52 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](MutexFunctions) - Mutex Functions
+INKMutexLockTry - [Next](INKMutexLockTry)
+### INKMutexLock
+
+Locks an `INKMutex`.
+
+**Prototype**
+  ~ `INKReturnCode INKMutexLock (INKMutex               <em class="replaceable"><code>mutexp`)
+
+**Description**
+  ~ Locks the `INKMutex` `<em class="replaceable"><code>mutexp`. If
+    `<em class="replaceable"><code>mutexp` is already locked, then
+    `INKMutexLock` blocks until the mutex is unlocked.
+
+  ~ An `INKMutex` will be recursively locked if `INKMutexLock` is
+    called on the same mutex twice from the same thread. Thus, the
+    following example will succeed and not block on the second call to
+    `INKMutexLock`.
+
+**Returns**
+  ~ `INK_SUCCESS` if the mutex is successfully locked.
+
+    `INK_ERROR` if an error occurs.
+
+**Example**
+  ~     INKMutexLock (some_mutex);
+        INKMutexLock (some_mutex);
+        INKMutexUnlock (some_mutex);
+        INKMutexUnlock (some_mutex);
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLockTry.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLockTry.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLockTry.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexLockTry.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,66 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKMutexLock) - INKMutexLock
+INKMutexUnlock - [Next](INKMutexUnlock)
+### INKMutexLockTry
+
+Tries to lock an `INKMutex`.
+
+**Prototype**
+  ~ `INKReturnCode InkMutexLockTry (INKMutex               <em class="replaceable"><code>mutex`,
+    int \**`lock`*)
+
+**Description**
+  ~ Tries to lock the `INKMutex`
+    `<em class="replaceable"><code>mutex`. Information about whether
+    the lock was grabbed is set in
+    `int               *``<em class="replaceable"><code>lock`.
+    `INKReturnCode` tells you if the call was successful or not, but
+    does not indicate if the lock was grabbed.
+
+    In general, use `InkMutexLockTry` to obtain a mutex (see the
+    example below).
+
+**Returns**
+  ~ `1` if the mutex is successfully locked.
+
+    `0` if the mutex is already locked.
+
+**Example**
+  ~     int handler (INKCont contp, INKEvent event, void *edata)
+        {
+           //This continuation tries to grab a mutex
+           int retval, lock = 0;
+        retvak = InkMutexLockTry (mutex, &lock);
+           if (!lock)
+           {
+           /* Schedule a retry; RETRY_TIME should be 10 ms or longer. */
+              INKContSchedule (contp, RETRY_TIME); 
+              return INK_EVENT_IMMEDIATE;
+           }
+        
+           // Now the mutex has been grabbed
+           do_some_job ...
+           INKMutexUnlock (mutexp);
+        }
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexUnlock.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexUnlock.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexUnlock.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKMutexUnlock.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,42 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKMutexLockTry) - INKMutexLockTry
+Continuation Functions - [Next](ContinuationFunctions)
+### INKMutexUnlock
+
+Unlocks an `INKMutex`.
+
+**Prototype**
+  ~ `INKReturnCode INKMutexUnlock (INKMutex                <em class="replaceable"><code>mutexp`)
+
+**Description**
+  ~ Unlocks the `INKMutex` `<em class="replaceable"><code> mutexp`.
+    If `<em class="replaceable"><code> mutexp` was recursively locked,
+    then `INKMutexUnlock` does not actually unlock the mutex - it
+    simply decrements the recursion count.
+
+**Returns**
+  ~ `INK_SUCCESS` if the mutex is successfully unlocked.
+
+    `INK_ERROR` if an error occurs.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetConnect.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetConnect.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetConnect.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetConnect.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,72 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](NetvconnectionFunctions) - Netvconnection Functions:
+INKNetAccept
+INKNetVConnRemoteIPGet - [Next](INKNetVConnRemoteIPGet)
+### INKNetConnect
+
+Initiates a network connection to a server.
+
+**Prototype**
+  ~ `INKAction INKNetConnect (INKCont               <em class="replaceable"><code>contp`,
+    unsigned int *`ip`*, int *`port`*)
+
+**Arguments**
+  ~ `INKCont` `<em class="replaceable"><code>contp` is the
+    continuation to be associated with the connection.
+
+    `int``<em class="replaceable"><code>ip` is the IP address, in
+    network byte order, of the host to connect with.
+
+    `int` `<em class="replaceable"><code>port` is port number for the
+    host, specified in network byte order.
+
+**Description**
+  ~ Opens a network connection to the host specified by
+    `<em class="replaceable"><code>ip` on the port specified by
+    `<em class="replaceable"><code>port`. If the connection is
+    successfully opened, then `<em class="replaceable"><code>contp` is
+    called back with the event `INK_EVENT_NET_CONNECT` and the new
+    network vconnection is passed in the event data parameter. If the
+    connection is not successful, then
+    `<em class="replaceable"><code>contp` is called back with the event
+    `INK_EVENT_NET_CONNECT_FAILED`.
+
+    ![[Note]](images/docbook/note.png)
+    Note
+    It's possible to receive `INK_EVENT_NET_CONNECT` even if the
+    connection failed because of the implementation of network sockets
+    in the underlying operating system. There is an exception: if a
+    plugin tries to open a connection to a port on its own host
+    machine, then `INK_EVENT_NET_CONNECT` is sent only if the
+    connection is successful. In general, however, your plugin needs to
+    look for `INK_EVENT_VCONN_WRITE_READY` or
+    `INK_EVENT_VCONN_READ_READY` to make sure the connection is
+    successfully opened.
+
+    Reentrant calls are possible; i.e., the net processor can call back
+    the user (`<em class="replaceable"><code>contp`) in the same call.
+
+**Returns**
+  ~ An `INKAction` object.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemoteIPGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemoteIPGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemoteIPGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemoteIPGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,49 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKNetConnect) - INKNetConnect
+INKNetVConnRemotePortGet - [Next](INKNetVConnRemotePortGet)
+### INKNetVConnRemoteIPGet
+
+Retrieves the remote host's IP address.
+
+**Prototype**
+  ~ `INKReturnCode INKNetVConnRemoteIPGet (INKVConn               <em class="replaceable"><code>vc`,
+    unsigned int \**`ip`*)
+
+**Arguments**
+  ~ `INKVConn` `<em class="replaceable"><code>vc` is the connection
+    between Traffic Server and the other end of the connection (can be
+    a remote client or server).
+
+    `unsigned int               *``<em class="replaceable"><code>ip` is
+    set to the remote IP address, in network byte order.
+
+**Description**
+  ~ Obtains the remote IP address in network byte order.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemotePortGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemotePortGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemotePortGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKNetVConnRemotePortGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,50 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKNetVConnRemoteIPGet) - INKNetVConnRemoteIPGet
+Cache Interface Functions - [Next](CacheInterfaceFunctions)
+### INKNetVConnRemotePortGet
+
+Retrieves the remote host's port number.
+
+**Prototype**
+  ~ `InkReturnCode INKNetVConnRemotePortGet (INKVConn               <em class="replaceable"><code>vc`,
+    int \**`port`*)
+
+**Arguments**
+  ~ `INKVConn <em class="replaceable">vc </em>``<em class="replaceable"><code>`
+    is the connection between Traffic Server and the other end of the
+    connection (can be remote client or server).
+
+    `int               *``<em class="replaceable"><code>port` is set to
+    the remote port value in host byte order.
+
+**Description**
+  ~ Obtains the port number of the remote host for the specified
+    connection. The port is returned in host byte order.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginDirGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginDirGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginDirGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginDirGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,49 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](CustInstallLicenseFunctions) - Customer Installation &
+Licensing Fxns: INKInstallDirGet
+INKPluginLicenseRequired - [Next](INKPluginLicenseRequired)
+### INKPluginDirGet
+
+Gets the plugin directory.
+
+**Prototype**
+  ~ `const char *INKPluginDirGet(void)`
+
+**Description**
+  ~ Gets the plugin directory relative to Traffic Server's install
+    directory. This path (relative to the Traffic Server install
+    directory) is stored in the `records.config` variable
+    `<i> proxy.config.plugin.plugin_dir</i>`. The default value is
+    `config/plugin`.
+
+**Example**
+  ~ To open the `Blacklist/ui/blacklist_config.txt` file, use the
+    following:
+
+        INKfopen ("INKInstallDirGet()/INKPluginDirGet()/Blacklist/ui/blacklist_config.txt");
+
+   
+**Returns**
+  ~ A pointer to a string containing the plugin directory.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginLicenseRequired.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginLicenseRequired.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginLicenseRequired.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginLicenseRequired.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,57 @@
+[![image](images/docbook/ts75.png)](/index)™
+# Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKPluginDirGet) - INKPluginDirGet
+Statistics Functions - [Next](StatisticsFunctions)
+### INKPluginLicenseRequired
+
+Specifies to Traffic Server that a license key is required for a
+plugin.
+
+**Prototype**
+  ~ `int INKPluginLicenseRequired(void)`
+
+**Description**
+  ~ Determines if a license is required. If a license is required,
+    then Traffic Server looks in the `plugin.db` file for the license
+    key. If this function is simply not defined, then the plugin does
+    not require a license.
+
+**Example**
+  ~     #include <stdio.h>
+        #include <ts/ts.h>
+        
+        void INKPluginInit (int argc, const char *argv[])
+        {
+            printf ("hello world\n");
+        }
+        int INKPluginLicenseRequired(void)
+        {
+            return 1;
+        }
+
+   
+**Returns**
+  ~ Returns `0` if a license is not required.
+
+    Returns `1` if a license is required.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginRegister.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginRegister.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginRegister.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKPluginRegister.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,58 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](InitializationFunctions) - Initialization Functions
+INKTrafficServerVersionGet -
+[Next](INKTrafficServerVersionGet)
+### INKPluginRegister
+
+Registers the appropriate SDK version for your plugin.
+
+**Prototype**
+  ~ `int INKPluginRegister (INKSDKVersion     <em class="replaceable"><code>sdk_version`,
+    INKPluginRegistrationInfo *`*plugin_info`*)
+
+**Arguments**
+  ~ *`sdk_version`* can have the following values:
+    -   `INK_SDK_VERSION_1_0`
+    -   `INK_SDK_VERSION_1_1`
+    -   `INK_SDK_VERSION_2_0`
+
+    > `INKPluginRegistrationInfo` is the following struct:
+    > 
+    >     typedef struct
+    >         {
+    >             char *plugin_name;
+    >             char *vendor_name;
+    >             char *support_email;
+    >         } INKPluginRegistrationInf
+
+**Description**
+  ~ Registers the appropriate SDK version for your plugin. Use this
+    function to ensure that your plugin is supported by the version of
+    Traffic Server it's running on. See the modified
+    [hello-world example](PlusingRegisAndVersionCkg "Plugin Registration and Version Checking")
+    that checks Traffic Server version for usage.
+
+**Returns**
+  ~ If plugin registration fails, then `0` is returned.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKReleaseAssert.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKReleaseAssert.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKReleaseAssert.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKReleaseAssert.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,42 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKAssert) - INKAssert
+The INKfopen Family - [Next](INKfopenFamilyFunctions)
+### INKReleaseAssert
+
+Allows the use of assertion in a plugin.
+
+**Prototype**
+  ~ `void               INKReleaseAssert(<em class="replaceable"><code>expression`);
+
+**Arguments**
+  ~ A Boolean expression.
+
+**Description**
+  ~ Allows the use of assertion in a plugin. If the expression is
+    false, then it causes Traffic Server in `debug` and `optim` mode to
+    print the file name, line number, and expression. Afterward, it
+    aborts.
+
+     
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectDestroy.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectDestroy.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectDestroy.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectDestroy.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,48 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](LoggingFunctions#INKTextLogObjectCreate) - Logging
+Functions: INKTextLogObjectCreate
+INKTextLogObjectFlush - [Next](INKTextLogObjectFlush)
+### INKTextLogObjectDestroy
+
+Destroys the custom log file created by `INKTextLogObjectCreate`.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectDestroy               (INKTextLogObject               <em class="replaceable"><code>the_object`)
+
+**Arguments**
+  ~ `INKTextLogObject` `<em class="replaceable"><code>the_object`
+    is the custom log file you want to destroy. You must first create
+    this object with `INKTextLogObjectCreate`.
+
+**Description**
+  ~ Destroys a log object (a plugin's custom log file) and releases
+    the memory allocated to it. Use this call if you're finished with
+    the log.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectFlush.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectFlush.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectFlush.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectFlush.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,50 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectDestroy) - INKTextLogObjectDestroy
+INKTextLogObjectHeaderSet - [Next](INKTextLogObjectHeaderSet)
+### INKTextLogObjectFlush
+
+Flushes the contents of a specified log file's log write buffer.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectFlush               (INKTextLogObject               <em class="replaceable"><code>the_object`)
+
+**Arguments**
+  ~ `INKTextLogObject` `<em class="replaceable"><code>the_object`
+    is the log file whose write buffer you want to flush. You have to
+    first create this object with `INKTextLogObjectCreate`.
+
+**Description**
+  ~ This immediately flushes to disk the contents of the log write
+    buffer for `<em class="replaceable"><code>the_object`. Use this
+    call only if you want to make sure that log entries are flushed
+    immediately. Also be aware that this call has a performance cost,
+    as Traffic Server automatically flushes the log buffer about every
+    second.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectHeaderSet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectHeaderSet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectHeaderSet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectHeaderSet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,52 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectFlush) - INKTextLogObjectFlush
+INKTextLogObjectRollingEnabledSet -
+[Next](INKTextLogObjectRollingEnabledSet)
+### INKTextLogObjectHeaderSet
+
+Sets a log file header.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectHeaderSet (INKTextLogObject <i class="replaceable">the_object</i>, const char *<i class="replaceable">header</i>)`
+
+**Arguments**
+  ~ `INKTextLogObject` `<i>the_object </i>` is the log object for
+    which you want to set the header.
+
+    `const char *<i class="replaceable">header </i>` is a log file
+    header.
+
+**Description**
+  ~ A header for a log object is the banner (i.e., a text line)
+    printed at the top of the log file. This API must be used once the
+    object is created (using `INKTextLogObjectCreate`) and before
+    writing into logs (using `INKTextLogObjectWrite`). By default, a
+    null header (empty line) is used.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingEnabledSet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingEnabledSet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingEnabledSet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingEnabledSet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,72 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectHeaderSet) - INKTextLogObjectHeaderSet
+INKTextLogObjectRollingIntervalSecSet -
+[Next](INKTextLogObjectRollingIntervalSecSet)
+### INKTextLogObjectRollingEnabledSet
+
+Enables/disables rolling for a log object.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectRollingEnabledSet (INKTextLogObject <i class="replaceable">the_object</i>, int *<i class="replaceable">rolling_enabled</i>)`
+
+**Arguments**
+  ~ `INKTextLogObject` `<i>the_object </i>` is the log object for
+    which you want to enable or disable rolling.
+
+    To enable rolling, set
+    `int <i class="replaceable">rolling_enabled </i>` to `1`; to
+    disable rolling, set to `0`.
+
+**Description**
+  ~ This API must be used once the object is created (using
+    `INKTextLogObjectCreate`) and before writing into logs (using
+    `INKTextLogObjectWrite`). If `INKTextLogObjectRollingEnabledSet` is
+    not called, then the default value (specified in `records.config`
+    by the parameter `<i>proxy.config.log2.rolling_enabled </i>`) is
+    used.
+
+    The rolling interval and offset can be specified via the APIs
+    `INKTextLogObjectRollingIntervalSecSet` and
+    `INKTextLogObjectRollingOffsetHrSet`.
+
+**Example**
+  ~ If rolling is enabled, then the rolling interval is set to
+    21600 sec (6 hours) and the offset hour is set to 0 (midnight).
+    This means the logs will be rolled at 0:00am (midnight), 06:00am,
+    12:00pm, and 18:00pm each day.
+
+    ![[Note]](images/docbook/note.png)
+    Note
+    If the maximum amount of disk space reserved for logs is exhausted
+    and if the parameter
+    `<i>proxy.config.log2.auto_delete_rolled_files </i>` is enabled in
+    `records.config`, then Traffic Server automatically deletes rolled
+    files to free up disk space.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingIntervalSecSet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingIntervalSecSet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingIntervalSecSet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingIntervalSecSet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,59 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectRollingEnabledSet) -
+INKTextLogObjectRollingEnabledSet
+INKTextLogObjectRollingOffsetHrSet -
+[Next](INKTextLogObjectRollingOffsetHrSet)
+### INKTextLogObjectRollingIntervalSecSet
+
+Sets the rolling interval for a log object.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectRollingIntervalSecSet               (INKTextLogObject <em class="replaceable"><code>the_object`,
+    int *`rolling_interval_sec`*)
+
+**Arguments**
+  ~ `INKTextLogObject` `<em class="replaceable"><code>the_object`
+    is the log object for which you want to set the rolling interval.
+
+    `int               <em class="replaceable"><code>rolling_interval_sec`
+    is the rolling interval (in seconds).
+
+**Description**
+  ~ This API must be used once the object is created (using
+    `INKTextLogObjectCreate`) and before writing into logs (using
+    `INKTextLogObjectWrite`). By default, a null header is used.
+
+    If `INKTextLogObjectRollingIntervalSecSet` is not called, then the
+    defaut value (specified in `records.config` by parameter
+    `<i>proxy.config.log2.rolling_interval_sec </i>`) is used.
+
+    The rolling offset can be specified using the API
+    `INKTextLogObjectRollingOffsetHrSet`.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingOffsetHrSet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingOffsetHrSet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingOffsetHrSet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectRollingOffsetHrSet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,58 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectRollingIntervalSecSet) -
+INKTextLogObjectRollingIntervalSecSet
+INKTextLogObjectWrite - [Next](INKTextLogObjectWrite)
+### INKTextLogObjectRollingOffsetHrSet
+
+Sets the rolling offset for a log object.
+
+**Prototype**
+  ~ `INKReturnCode INKTextLogObjectRollingOffsetHrSet (INKTextLogObject <em class="replaceable"><code>the_object`,
+    int *`rolling_offset_hr`*)
+
+**Arguments**
+  ~ `INKTextLogObject` `<em class="replaceable"><code>the_object`
+    is the log object for which you want to set the rolling offset.
+
+    `i``nt               <em class="replaceable"><code>rolling_offset_hr`
+    is the rolling interval (in seconds).
+
+**Description**
+  ~ This API must be used once the object is created (using
+    `INKTextLogObjectCreate`) and before writing into logs (using
+    `INKTextLogObjectWrite`). By default, a null header is used.
+
+    If `INKTextLogObjectRollingOffsetHrSet` is not called, then the
+    defaut value (specified in `records.config` by parameter
+    `<i>proxy.config.log2.rolling_offset_hr </i>`) is used.
+
+    The rolling interval can be specified using the API
+    `INKTextLogObjectRollingIntervalSecSet`.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectWrite.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectWrite.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectWrite.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTextLogObjectWrite.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,65 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKTextLogObjectRollingOffsetHrSet) -
+INKTextLogObjectRollingOffsetHrSet
+Appendix A. Sample Source Code - [Next](App_SampleSourceCode)
+### INKTextLogObjectWrite
+
+Writes a text entry to a custom log file.
+
+**Prototype**
+  ~ `InkReturnCode INKTextLogObjectWrite               (INKTextLogObject <em class="replaceable"><code>the_object`,
+    char \**`format`*, ...)
+
+**Arguments**
+  ~ `<em class="replaceable"><code>the_object` is the log object to
+    write to. You must first create this log file with
+    `INKTextLogObjectCreate`.
+
+    `char *<em class="replaceable"><code>format` is a printf-style
+    formatted statement to be printed.
+
+    `...`corresponds to the parameters in the formatted statement. A
+    new line is automatically added to the end.
+
+**Description**
+  ~ Writes a text entry to a custom log file.
+
+**Example**
+  ~ Suppose you call the following:
+
+        int my_value = 2001;
+        INKTextLogObjectWrite (log, "my value: %d", my_value);
+
+    If `<i>mode </i>` is set to `ADD_TIMESTAMP`, then the log should
+    look like:
+
+        <timestamp> my value: 2001 
+
+   
+ **Returns** 
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadDestroy.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadDestroy.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadDestroy.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadDestroy.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,41 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](ThreadFunctions) - Thread Functions
+INKThreadInit - [Next](INKThreadInit)
+### INKThreadDestroy
+
+Destroys a thread.
+
+**Prototype**
+  ~ `INKReturnCode INKThreadDestroy (INKThread               <em class="replaceable"><code>thread`)
+
+**Description**
+  ~ Destroys a thread and frees all memory & associated data
+    structures. This should only be called on threads that have been
+    initialized using `INKThreadInit`.
+
+**Returns**
+  ~ `INK_SUCCESS` if successful.
+
+    `INK_ERROR` if an error occurs.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadInit.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadInit.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadInit.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadInit.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,42 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKThreadDestroy) - INKThreadDestroy
+INKThreadSelf - [Next](INKThreadSelf)
+### INKThreadInit
+
+Initializes a thread.
+
+**Prototype**
+  ~ `INKThread INKThreadInit (void)`
+
+**Description**
+  ~ Initializes a thread for use by Traffic Server. This function
+    should only be used if you create your own thread using something
+    other than the `INKThreadCreate` function. It should not be called
+    more than once for any given thread.
+
+**Returns**
+  ~ A valid pointer to an `INKThread` object if successful.
+
+    A `NULL` pointer if there is an error.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadSelf.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadSelf.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadSelf.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKThreadSelf.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,40 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKThreadInit) - INKThreadInit
+HTTP Functions - [Next](HTTPFunctions)
+### INKThreadSelf
+
+Obtains a thread identifier.
+
+**Prototype**
+  ~ `INKThread INKThreadSelf (void)`
+
+**Description**
+  ~ Returns the thread identifier for the thread that's currently
+    being executed.
+
+**Returns**
+  ~ A valid pointer to an `INKThread` object if successful.
+
+    A `NULL` pointer if there is an error.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTrafficServerVersionGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTrafficServerVersionGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTrafficServerVersionGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTrafficServerVersionGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,41 @@
+[![image](images/docbook/ts75.png)](/index)™
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKPluginRegister) - INKPluginRegister
+Debugging Functions - [Next](DebuggingFunctions)
+### INKTrafficServerVersionGet
+
+Returns the version of Traffic Server that's running the plugin.
+
+**Prototype**
+  ~ `const char* INKTrafficServerVersionGet               (void)`
+
+**Description**
+  ~ Returns the string that indicates the release version of
+    Traffic Server running the plugin. See the modified
+    [`hello-world`](PlusingRegisAndVersionCkg "Plugin Registration and Version Checking")
+    example that checks the Traffic Server version for usage.
+
+**Returns**
+  ~ A pointer to a string of characters that indicates the Traffic
+    Server release version.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTransformOutputVConnGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTransformOutputVConnGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTransformOutputVConnGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKTransformOutputVConnGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,46 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](TransformationFunctions) - Transformation Functions:
+INKTransformCreate
+VIO Functions - [Next](VIOFunctions)
+### INKTransformOutputVConnGet
+
+Retrieves the downstream (output) vconnection for a
+transformation.
+
+**Prototype**
+  ~ `INKVConn INKTransformOutputVConnGet (INKVConn               <em class="replaceable"><code>connp`)
+
+**Description**
+  ~ Retrieves the output vconnection for the transformation
+    `<em class="replaceable"><code>connp`. The output vconnection may
+    be `NULL` if `INKTransformOutputVConnGet` is called before the
+    write operation is initiated on
+    `<em class="replaceable"><code>connp`. This is normally not an
+    issue, however, since a transformation would not want to output
+    data until it has data input into it.
+
+**Returns**
+  ~ The downstream vconnection for the transformation.
+
+    `INK_ERROR_PTR` if there is an error.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnCacheObjectSizeGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnCacheObjectSizeGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnCacheObjectSizeGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnCacheObjectSizeGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,49 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKCacheKeyPinnedSet) - INKCacheKeyPinnedSet
+Transformation Functions - [Next](TransformationFunctions)
+### INKVConnCacheObjectSizeGet
+
+Gets the size of an object in the cache.
+
+**Prototype**
+  ~ `INKReturnCode INKVConnCacheObjectSizeGet (INKVConn               <em class="replaceable"><code>connp`,
+    int \**`obj_size`*)
+
+**Arguments**
+  ~ `INKConn` `<em class="replaceable"><code>connp` is the
+    vconnection to the cache.
+
+    `int *<em class="replaceable"><code>obj_size` is set to the object
+    size.
+
+**Description**
+  ~ When a cached object is requested from the cache (using
+    `INKCacheRead`) and if the cache open was successful, then this
+    function can be called to get the size of the object in the cache.
+
+**Returns**
+  ~ `INK_SUCCESS` if the API is called successfully.
+
+    `INK_ERROR` if an error occurs while calling the API or if an
+    argument is invalid.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClose.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClose.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClose.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClose.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,43 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](VconnectionFunctions) - Vconnection Functions:
+INKVConnAbort
+INKVConnClosedGet - [Next](INKVConnClosedGet)
+### INKVConnClose
+
+Closes a vconnection.
+
+**Prototype**
+  ~ `INKReturnCode INKVConnClose (INKVConn               <em class="replaceable"><code>connp`)
+
+**Description**
+  ~ Closes the vconnection `<em class="replaceable"><code> connp`.
+    The vconnection will be deallocated at some point in the near
+    future, after `INKVConnClose` is called. After calling
+    `INKVConnClose`, a user will not receive any more events from
+    `<em class="replaceable"><code>connp`.
+
+**Returns**
+  ~ `INK_SUCCESS` if the connection is successfully closed.
+
+    `INK_ERROR` if an error occurs.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClosedGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClosedGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClosedGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnClosedGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,50 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKVConnClose) - INKVConnClose
+INKVConnRead - [Next](INKVConnRead)
+### INKVConnClosedGet
+
+Gets a closed vconnection.
+
+**Prototype**
+  ~ `INKReturnCode INKVConnClosedGet (INKVConn               <em class="replaceable"><code>connp`)
+
+**Description**
+  ~ Retrieves the closed status for a vconnection.
+
+    `INKVConnClosedGet` is intended to be used by vconnection
+    implementors and not by vconnection users. It is not safe for a
+    vconnection user to call `INKVConnClosedGet` because if the
+    vconnection actually is closed, then it is possible (and likely) it
+    will/can be deallocated at any time.
+
+    ![[Note]](images/docbook/note.png)
+    Note
+    This API can be used **ONLY** on transformation VConnections.
+    **NEVER** use it on Cache VConnections, Net VConnections or any
+    other type of VConnection.
+
+**Returns**
+  ~ `INK_SUCCESS` if successful.
+
+    `INK_ERROR` if an error occurs.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnRead.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnRead.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnRead.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnRead.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,49 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKVConnClosedGet) - INKVConnClosedGet
+INKVConnReadVIOGet - [Next](INKVConnReadVIOGet)
+### INKVConnRead
+
+Reads a vconnection.
+
+**Prototype**
+  ~ `INKVIO INKVConnRead (INKVConn               <em class="replaceable"><code>connp`,
+    INKCont *`contp`*, INKIOBuffer *`bufp`*, int *`nbytes`*)
+
+**Description**
+  ~ Initiates a read operation on the vconnection
+    `<em class="replaceable"><code>connp`. The read operation writes
+    into the buffer `<em class="replaceable"><code> bufp`. The
+    continuation `<em class="replaceable"><code> contp` is called back
+    with either `INK_EVENT_ERROR`, `INK_EVENT_VCONN_READ_READY`,
+    `INK_EVENT_VCONN_READ_COMPLETE`, or `INK_EVENT_VCONN_EOS` (refer to
+    the
+    [vconnection user's view](IOGuide#VconnectionUsersView "The vconnection user's view")
+    for more information about these events). The number of bytes to
+    read is specified by the `<em class="replaceable"><code> nbytes`
+    parameter.
+
+**Returns**
+  ~ A handle to the vconnection.
+
+    `INK_ERROR_PTR` if an error occurs.
+
+
 
 

Modified: trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnReadVIOGet.en.mdtext
URL: http://svn.apache.org/viewvc/trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnReadVIOGet.en.mdtext?rev=1031963&r1=1031962&r2=1031963&view=diff
==============================================================================
--- trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnReadVIOGet.en.mdtext (original)
+++ trafficserver/site/branches/ats-cms/content/docs/trunk/sdk/INKVConnReadVIOGet.en.mdtext Sat Nov  6 06:29:56 2010
@@ -1,2 +1,45 @@
+Title: Apache Traffic Server™ Software Developers Kit
+Notice:    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.
+
+[Prev](INKVConnRead) - INKVConnRead
+INKVConnShutdown - [Next](INKVConnShutdown)
+### INKVConnReadVIOGet
+
+Obtains the output VIO for a vconnection.
+
+**Prototype**
+  ~ `INKVIO INKVConnReadVIOGet (INKVConn               <em class="replaceable"><code>connp`)
+
+**Description**
+  ~ Retrieves the read VIO for a vconnection. `INKVConnReadVIOGet`
+    should be used by vconnection implementors and not by vconnection
+    users.
+
+    ![[Note]](images/docbook/note.png)
+    Note
+    This API can only be used for transformations; it is not used for
+    `NetVConn` or `CacheVConn`.
+
+**Returns**
+  ~ A handle to the vconnection.
+
+    `INK_ERROR_PTR` if an error occurs.
+
+