You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hawq.apache.org by es...@apache.org on 2016/09/08 05:20:45 UTC

[06/54] [partial] incubator-hawq git commit: HAWQ-959. revert thrift build commands.

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketClient.m
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketClient.m b/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketClient.m
deleted file mode 100644
index d8c55d6..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketClient.m
+++ /dev/null
@@ -1,261 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-#import <Foundation/Foundation.h>
-#import <CoreFoundation/CoreFoundation.h>
-#import "TSSLSocketClient.h"
-#import "TSSLSocketException.h"
-#import "TObjective-C.h"
-#include <sys/socket.h>
-#include <netinet/in.h>
-#include <netdb.h>
-
-#if !TARGET_OS_IPHONE
-#import <CoreServices/CoreServices.h>
-#else
-#import <CFNetwork/CFNetwork.h>
-#endif
-
-@implementation TSSLSocketClient
-
-- (id) initWithHostname: (NSString *) hostname
-                   port: (int) port
-{
-    sslHostname = hostname;
-	CFReadStreamRef readStream = NULL;
-	CFWriteStreamRef writeStream = NULL;
-    
-    
-    /* create a socket structure */
-    struct sockaddr_in pin;
-    struct hostent *hp = NULL;
-    for(int i = 0; i < 10; i++) {
-        
-
-        
-        if ((hp = gethostbyname([hostname UTF8String])) == NULL) { 
-            NSLog(@"failed to resolve hostname %@", hostname);
-            herror("resolv");
-            if(i == 9) {
-                @throw [TSSLSocketException exceptionWithReason: @"failed to resolve hostname"];
-            }
-            [NSThread sleepForTimeInterval:0.2];
-        } else {
-            break;
-        }
-    }
-
-    memset (&pin, 0, sizeof(pin));
-    pin.sin_family = AF_INET;
-    memcpy(&pin.sin_addr, hp->h_addr, sizeof(struct in_addr));
-    pin.sin_port = htons (port);
-    
-    /* create the socket */
-    if ((sd = socket (AF_INET, SOCK_STREAM, IPPROTO_TCP)) == -1)
-    {
-        NSLog(@"failed to create socket for host %@:%d", hostname, port);
-        @throw [TSSLSocketException exceptionWithReason: @"failed to create socket"];
-    }
-    
-    /* open a connection */
-    if (connect (sd, (struct sockaddr *) &pin, sizeof(pin)) == -1)
-    {
-        NSLog(@"failed to create conenct to host %@:%d", hostname, port);
-        @throw [TSSLSocketException exceptionWithReason: @"failed to connect"];
-    }
-    CFStreamCreatePairWithSocket(kCFAllocatorDefault, sd, &readStream, &writeStream);
-    
-    CFReadStreamSetProperty(readStream, kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-    CFWriteStreamSetProperty(writeStream, kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-    
-	if (readStream && writeStream) {
-        CFReadStreamSetProperty(readStream,
-                                kCFStreamPropertySocketSecurityLevel,
-                                kCFStreamSocketSecurityLevelTLSv1);
-        
-        NSDictionary *settings =
-        [NSDictionary dictionaryWithObjectsAndKeys:
-         (id)kCFBooleanTrue, (id)kCFStreamSSLValidatesCertificateChain,
-         nil];
-        
-        CFReadStreamSetProperty((CFReadStreamRef)readStream,
-                                kCFStreamPropertySSLSettings,
-                                (CFTypeRef)settings);
-        CFWriteStreamSetProperty((CFWriteStreamRef)writeStream,
-                                 kCFStreamPropertySSLSettings,
-                                 (CFTypeRef)settings);
-        
-		inputStream = (bridge_stub NSInputStream *)readStream;
-		[inputStream retain_stub];
-		[inputStream setDelegate:self];
-   		[inputStream scheduleInRunLoop:[NSRunLoop mainRunLoop] forMode:NSDefaultRunLoopMode];
-		[inputStream open];
-		
-		outputStream = (bridge_stub NSOutputStream *)writeStream;
-		[outputStream retain_stub];
-		[outputStream setDelegate:self];
-        [outputStream scheduleInRunLoop:[NSRunLoop mainRunLoop] forMode:NSDefaultRunLoopMode];
-		[outputStream open];
-        
-        
-        CFRelease(readStream);
-        CFRelease(writeStream);
-	}
-    
-    
-	
-	self = [super initWithInputStream: inputStream outputStream: outputStream];
-    
-	return self;
-}
-
-#pragma mark -
-#pragma mark NSStreamDelegate
-- (void)stream:(NSStream *)aStream
-    handleEvent:(NSStreamEvent)eventCode {
-    switch (eventCode) {
-        case NSStreamEventNone:
-            break;
-        case NSStreamEventHasBytesAvailable:
-            break;
-        case NSStreamEventOpenCompleted:
-            break;
-        case NSStreamEventHasSpaceAvailable:
-        {
-            SecPolicyRef policy = SecPolicyCreateSSL(NO, (__bridge CFStringRef)(sslHostname));
-            SecTrustRef trust = NULL;
-            CFArrayRef streamCertificatesRef =
-            CFBridgingRetain((__bridge id)((__bridge CFArrayRef)([aStream propertyForKey:(NSString *) kCFStreamPropertySSLPeerCertificates])));
-            SecTrustCreateWithCertificates(CFBridgingRetain((__bridge id)(streamCertificatesRef)),
-                                           policy,
-                                           &trust);
-            
-            SecTrustResultType trustResultType = kSecTrustResultInvalid;
-            SecTrustEvaluate(trust, &trustResultType);
-            
-            BOOL proceed = NO;
-            switch (trustResultType) {
-                case kSecTrustResultProceed:
-                    proceed = YES;
-                    break;
-                case kSecTrustResultUnspecified:
-                    NSLog(@"Trusted by OS");
-                    proceed = YES;
-                    break;
-                case kSecTrustResultRecoverableTrustFailure:
-                    proceed = recoverFromTrustFailure(trust);
-                    break;
-                case kSecTrustResultDeny:
-                    NSLog(@"Deny");
-                    break;
-                case kSecTrustResultFatalTrustFailure:
-                    NSLog(@"FatalTrustFailure");
-                    break;
-                case kSecTrustResultOtherError:
-                    NSLog(@"OtherError");
-                    break;
-                case kSecTrustResultInvalid:
-                    NSLog(@"Invalid");
-                    break;
-                default:
-                    NSLog(@"Default");
-                    break;
-            }
-            
-            if (trust) {
-                CFRelease(trust);
-            }
-            if (policy) {
-                CFRelease(policy);
-            }
-            if (!proceed) {
-                NSLog(@"Cannot trust certificate. TrustResultType: %u", trustResultType);
-                [aStream close];
-                @throw [TSSLSocketException exceptionWithReason: @"Cannot trust certificate"];
-            }
-        }
-            break;
-        case NSStreamEventErrorOccurred:
-        {
-            NSError *theError = [aStream streamError];
-            NSLog(@"Error occurred opening stream: %@", theError);
-//            @throw [TSSLSocketException exceptionWithReason: @"Error occurred opening stream" error: theError];
-            break;
-        }
-        case NSStreamEventEndEncountered:
-            break;
-    }
-}
-
-bool recoverFromTrustFailure(SecTrustRef myTrust)
-{
-    
-    SecTrustResultType trustResult;
-    OSStatus status = SecTrustEvaluate(myTrust, &trustResult);
-    
-    CFAbsoluteTime trustTime,currentTime,timeIncrement,newTime;
-    CFDateRef newDate;
-    if (trustResult == kSecTrustResultRecoverableTrustFailure) {
-        trustTime = SecTrustGetVerifyTime(myTrust);
-        timeIncrement = 31536000;
-        currentTime = CFAbsoluteTimeGetCurrent();
-        newTime = currentTime - timeIncrement;
-        if (trustTime - newTime){
-            newDate = CFDateCreate(NULL, newTime);
-            SecTrustSetVerifyDate(myTrust, newDate);
-            status = SecTrustEvaluate(myTrust, &trustResult);
-        }
-    }
-    if (trustResult != kSecTrustResultProceed) {
-        NSLog(@"Certificate trust failure");
-        return false;
-    }
-    return true;
-}
-
-- (void)close
-{
-    if(self.mInput) {
-        //Close and reset inputstream
-        CFReadStreamSetProperty((__bridge CFReadStreamRef)(self.mInput), kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-        [self.mInput setDelegate:nil];
-        [self.mInput close];
-        [self.mInput removeFromRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-        self.mInput = nil;
-    }
-    
-    if(self.mOutput) {
-        //Close and reset outputstream
-        CFReadStreamSetProperty((__bridge CFReadStreamRef)(self.mOutput), kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-        [self.mOutput setDelegate:nil];
-        [self.mOutput close];
-        [self.mOutput removeFromRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-        self.mOutput = nil;
-    }
-}
-
-- (BOOL) isOpen
-{
-    if(sd > 0)
-        return TRUE;
-    else
-        return FALSE;
-}
-
-@end
-

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.h
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.h b/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.h
deleted file mode 100644
index c290b05..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.h
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#import "TTransportException.h"
-
-@interface TSSLSocketException : TTransportException
-
-+ (id) exceptionWithReason: (NSString *) reason
-                     error: (NSError *) error;
-
-+ (id) exceptionWithReason: (NSString *) reason;
-
-@end

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.m
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.m b/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.m
deleted file mode 100644
index 99eadf5..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSSLSocketException.m
+++ /dev/null
@@ -1,42 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#import "TSSLSocketException.h"
-
-@implementation TSSLSocketException
-
-+ (id) exceptionWithReason: (NSString *) reason
-                     error: (NSError *) error
-{
-    NSDictionary * userInfo = nil;
-    if (error != nil) {
-        userInfo = [NSDictionary dictionaryWithObject: error forKey: @"error"];
-    }
-    
-    return [super exceptionWithName: @"TSSLSocketException"
-                             reason: reason
-                           userInfo: userInfo];
-}
-
-+ (id) exceptionWithReason: (NSString *) reason
-{
-    return [self exceptionWithReason: reason error: nil];
-}
-
-@end

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.h
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.h b/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.h
deleted file mode 100644
index 81a0247..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.h
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#import <Foundation/Foundation.h>
-#import "TNSStreamTransport.h"
-
-@interface TSocketClient : TNSStreamTransport 
-#if TARGET_OS_IPHONE || (MAC_OS_X_VERSION_MAX_ALLOWED >= MAC_OS_X_VERSION_10_6)
-<NSStreamDelegate>
-#endif
-{
-}
-
-- (id) initWithHostname: (NSString *) hostname
-                   port: (UInt32) port;
-
-@end
-
-
-

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.m
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.m b/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.m
deleted file mode 100644
index b0bac74..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TSocketClient.m
+++ /dev/null
@@ -1,87 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-#import "TSocketClient.h"
-#import "TObjective-C.h"
-
-#if !TARGET_OS_IPHONE
-#import <CoreServices/CoreServices.h>
-#else
-#import <CFNetwork/CFNetwork.h>
-#endif
-
-@interface TSocketClient ()
-{
-    NSInputStream * inputStream;
-	NSOutputStream * outputStream;
-}
-@end
-
-@implementation TSocketClient
-
-- (id) initWithHostname: (NSString *) hostname
-                   port: (UInt32) port
-{
-	inputStream = NULL;
-	outputStream = NULL;
-	CFReadStreamRef readStream = NULL;
-	CFWriteStreamRef writeStream = NULL;
-	CFStreamCreatePairWithSocketToHost(kCFAllocatorDefault, (bridge_stub CFStringRef)hostname, port, &readStream, &writeStream);
-	if (readStream && writeStream) {
-		CFReadStreamSetProperty(readStream, kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-		CFWriteStreamSetProperty(writeStream, kCFStreamPropertyShouldCloseNativeSocket, kCFBooleanTrue);
-		
-		inputStream = (bridge_stub NSInputStream *)readStream;
-		[inputStream retain_stub];
-		[inputStream setDelegate:self];
-		[inputStream scheduleInRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-		[inputStream open];
-		
-		outputStream = (bridge_stub NSOutputStream *)writeStream;
-		[outputStream retain_stub];
-		[outputStream setDelegate:self];
-		[outputStream scheduleInRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-		[outputStream open];
-        CFRelease(readStream);
-        CFRelease(writeStream);
-	}
-	
-	self = [super initWithInputStream: inputStream outputStream: outputStream];
-	
-	return self;
-}
-
--(void)dealloc
-{
-    [inputStream close];
-    [inputStream removeFromRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-    [inputStream setDelegate:nil];
-    [inputStream release_stub];
-    
-    [outputStream close];
-    [outputStream removeFromRunLoop:[NSRunLoop currentRunLoop] forMode:NSDefaultRunLoopMode];
-    [outputStream setDelegate:nil];
-    [outputStream release_stub];
-    [super dealloc_stub];
-}
-
-
-@end
-
-
-

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransport.h
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransport.h b/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransport.h
deleted file mode 100644
index 83aad9e..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransport.h
+++ /dev/null
@@ -1,36 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-@protocol TTransport <NSObject>
-
-  /**
-   * Guarantees that all of len bytes are read
-   *
-   * @param buf Buffer to read into
-   * @param offset Index in buffer to start storing bytes at
-   * @param length Maximum number of bytes to read
-   * @return The number of bytes actually read, which must be equal to len
-   * @throws TTransportException if there was an error reading data
-   */
-- (size_t) readAll: (uint8_t *) buf offset: (size_t) offset length: (size_t) length;
-
-- (void) write: (const uint8_t *) data offset: (size_t) offset length: (size_t) length;
-
-- (void) flush;
-@end

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.h
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.h b/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.h
deleted file mode 100644
index 6749fe2..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.h
+++ /dev/null
@@ -1,30 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#import "TException.h"
-
-@interface TTransportException : TException {
-}
-
-+ (id) exceptionWithReason: (NSString *) reason
-                     error: (NSError *) error;
-
-+ (id) exceptionWithReason: (NSString *) reason;
-
-@end

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.m
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.m b/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.m
deleted file mode 100644
index 43cdfbd..0000000
--- a/depends/thirdparty/thrift/lib/cocoa/src/transport/TTransportException.m
+++ /dev/null
@@ -1,44 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#import "TTransportException.h"
-#import "TObjective-C.h"
-
-@implementation TTransportException
-
-+ (id) exceptionWithReason: (NSString *) reason
-                     error: (NSError *) error
-{
-  NSDictionary * userInfo = nil;
-  if (error != nil) {
-    userInfo = [NSDictionary dictionaryWithObject: error forKey: @"error"];
-  }
-
-  return [super exceptionWithName: @"TTransportException"
-                           reason: reason
-                         userInfo: userInfo];
-}
-
-
-+ (id) exceptionWithReason: (NSString *) reason
-{
-  return [self exceptionWithReason: reason error: nil];
-}
-
-@end

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/3rdparty.props
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/3rdparty.props b/depends/thirdparty/thrift/lib/cpp/3rdparty.props
deleted file mode 100644
index 528d40a..0000000
--- a/depends/thirdparty/thrift/lib/cpp/3rdparty.props
+++ /dev/null
@@ -1,25 +0,0 @@
-\ufeff<?xml version="1.0" encoding="utf-8"?>
-<Project ToolsVersion="4.0" xmlns="http://schemas.microsoft.com/developer/msbuild/2003">
-  <ImportGroup Label="PropertySheets" />
-  <PropertyGroup Label="UserMacros">
-    <BOOST_ROOT>$(THIRD_PARTY)\boost\boost_1_47_0</BOOST_ROOT>
-    <OPENSSL_ROOT_DIR>$(THIRD_PARTY)\openssl\OpenSSL-Win32</OPENSSL_ROOT_DIR>
-    <LIBEVENT_ROOT>$(THIRD_PARTY)\libevent-2.0.21-stable</LIBEVENT_ROOT>
-  </PropertyGroup>
-  <PropertyGroup />
-  <ItemDefinitionGroup />
-  <ItemGroup>
-    <BuildMacro Include="BOOST_ROOT">
-      <Value>$(BOOST_ROOT)</Value>
-      <EnvironmentVariable>true</EnvironmentVariable>
-    </BuildMacro>
-    <BuildMacro Include="OPENSSL_ROOT_DIR">
-      <Value>$(OPENSSL_ROOT_DIR)</Value>
-      <EnvironmentVariable>true</EnvironmentVariable>
-    </BuildMacro>
-    <BuildMacro Include="LIBEVENT_ROOT">
-      <Value>$(LIBEVENT_ROOT)</Value>
-      <EnvironmentVariable>true</EnvironmentVariable>
-    </BuildMacro>
-  </ItemGroup>
-</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/CMakeLists.txt
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/CMakeLists.txt b/depends/thirdparty/thrift/lib/cpp/CMakeLists.txt
deleted file mode 100755
index 4c7caeb..0000000
--- a/depends/thirdparty/thrift/lib/cpp/CMakeLists.txt
+++ /dev/null
@@ -1,209 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements. See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership. The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License. You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied. See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-# Find required packages
-if(WITH_BOOSTTHREADS)
-  find_package(Boost 1.53.0 REQUIRED COMPONENTS system thread)
-else()
-  find_package(Boost 1.53.0 REQUIRED)
-endif()
-
-include_directories(SYSTEM "${Boost_INCLUDE_DIRS}")
-include_directories(src)
-
-# SYSLIBS contains libraries that need to be linked to all lib targets
-set(SYSLIBS "")
-
-# Create the thrift C++ library
-set( thriftcpp_SOURCES
-   src/thrift/TApplicationException.cpp
-   src/thrift/TOutput.cpp
-   src/thrift/async/TAsyncChannel.cpp
-   src/thrift/async/TConcurrentClientSyncInfo.h
-   src/thrift/async/TConcurrentClientSyncInfo.cpp
-   src/thrift/concurrency/ThreadManager.cpp
-   src/thrift/concurrency/TimerManager.cpp
-   src/thrift/concurrency/Util.cpp
-   src/thrift/processor/PeekProcessor.cpp
-   src/thrift/protocol/TBase64Utils.cpp
-   src/thrift/protocol/TDebugProtocol.cpp
-   src/thrift/protocol/TJSONProtocol.cpp
-   src/thrift/protocol/TMultiplexedProtocol.cpp
-   src/thrift/protocol/TProtocol.cpp
-   src/thrift/transport/TTransportException.cpp
-   src/thrift/transport/TFDTransport.cpp
-   src/thrift/transport/TSimpleFileTransport.cpp
-   src/thrift/transport/THttpTransport.cpp
-   src/thrift/transport/THttpClient.cpp
-   src/thrift/transport/THttpServer.cpp
-   src/thrift/transport/TSocket.cpp
-   src/thrift/transport/TSocketPool.cpp
-   src/thrift/transport/TServerSocket.cpp
-   src/thrift/transport/TTransportUtils.cpp
-   src/thrift/transport/TBufferTransports.cpp
-   src/thrift/server/TConnectedClient.cpp
-   src/thrift/server/TServerFramework.cpp
-   src/thrift/server/TSimpleServer.cpp
-   src/thrift/server/TThreadPoolServer.cpp
-   src/thrift/server/TThreadedServer.cpp
-)
-
-# This files don't work on Windows CE as there is no pipe support
-# TODO: These files won't work with UNICODE support on windows. If fixed this can be re-added.
-if (NOT WINCE)
-    list(APPEND thriftcpp_SOURCES
-       src/thrift/transport/TPipe.cpp
-       src/thrift/transport/TPipeServer.cpp
-       src/thrift/transport/TFileTransport.cpp
-    )
-endif()
-
-
-if (WIN32)
-    list(APPEND thriftcpp_SOURCES
-        src/thrift/windows/TWinsockSingleton.cpp
-        src/thrift/windows/SocketPair.cpp
-        src/thrift/windows/GetTimeOfDay.cpp
-        src/thrift/windows/WinFcntl.cpp
-    )
-    if(NOT WINCE)
-        # This file uses pipes so it currently won't work on Windows CE
-        list(APPEND thriftcpp_SOURCES
-            src/thrift/windows/OverlappedSubmissionThread.cpp
-        )
-    endif()
-else()
-    # These files evaluate to nothing on Windows, so omit them from the
-    # Windows build
-    list(APPEND thriftcpp_SOURCES
-        src/thrift/VirtualProfiling.cpp
-        src/thrift/server/TServer.cpp
-    )
-endif()
-
-# If OpenSSL is not found just ignore the OpenSSL stuff
-find_package(OpenSSL)
-if(OPENSSL_FOUND AND WITH_OPENSSL)
-    list( APPEND thriftcpp_SOURCES
-       src/thrift/transport/TSSLSocket.cpp
-       src/thrift/transport/TSSLServerSocket.cpp
-    )
-    include_directories(SYSTEM "${OPENSSL_INCLUDE_DIR}")
-    list(APPEND SYSLIBS "${OPENSSL_LIBRARIES}")
-endif()
-
-# WITH_*THREADS selects which threading library to use
-if(WITH_BOOSTTHREADS)
-    set( thriftcpp_threads_SOURCES
-        src/thrift/concurrency/BoostThreadFactory.cpp
-        src/thrift/concurrency/BoostMonitor.cpp
-        src/thrift/concurrency/BoostMutex.cpp
-    )
-    list(APPEND SYSLIBS "${Boost_LIBRARIES}")
-elseif(UNIX AND NOT WITH_STDTHREADS)
-    list(APPEND SYSLIBS pthread)
-    set( thriftcpp_threads_SOURCES
-        src/thrift/concurrency/PosixThreadFactory.cpp
-        src/thrift/concurrency/Mutex.cpp
-        src/thrift/concurrency/Monitor.cpp
-    )
-else()
-    if(UNIX)
-        # need pthread for multi-thread support
-        list(APPEND SYSLIBS pthread)
-    endif()
-    set( thriftcpp_threads_SOURCES
-        src/thrift/concurrency/StdThreadFactory.cpp
-        src/thrift/concurrency/StdMutex.cpp
-        src/thrift/concurrency/StdMonitor.cpp
-    )
-endif()
-
-# Thrift non blocking server
-set( thriftcppnb_SOURCES
-    src/thrift/server/TNonblockingServer.cpp
-    src/thrift/async/TAsyncProtocolProcessor.cpp
-    src/thrift/async/TEvhttpServer.cpp
-    src/thrift/async/TEvhttpClientChannel.cpp
-)
-
-# Thrift zlib server
-set( thriftcppz_SOURCES
-    src/thrift/transport/TZlibTransport.cpp
-)
-
-# Thrift Qt4 server
-set( thriftcppqt_SOURCES
-    src/thrift/qt/TQIODeviceTransport.cpp
-    src/thrift/qt/TQTcpServer.cpp
-)
-
-# Contains the thrift specific ADD_LIBRARY_THRIFT and TARGET_LINK_LIBRARIES_THRIFT
-include(ThriftMacros)
-
-ADD_LIBRARY_THRIFT(thrift ${thriftcpp_SOURCES} ${thriftcpp_threads_SOURCES})
-TARGET_LINK_LIBRARIES_THRIFT(thrift ${SYSLIBS})
-
-if(WITH_LIBEVENT)
-    find_package(Libevent REQUIRED)  # Libevent comes with CMake support form upstream
-    include_directories(SYSTEM ${LIBEVENT_INCLUDE_DIRS})
-
-    ADD_LIBRARY_THRIFT(thriftnb ${thriftcppnb_SOURCES})
-    TARGET_LINK_LIBRARIES_THRIFT(thriftnb ${SYSLIBS} ${LIBEVENT_LIBRARIES})
-    TARGET_LINK_LIBRARIES_THRIFT_AGAINST_THRIFT_LIBRARY(thriftnb thrift)
-endif()
-
-if(WITH_ZLIB)
-    find_package(ZLIB REQUIRED)
-    include_directories(SYSTEM ${ZLIB_INCLUDE_DIRS})
-
-    ADD_LIBRARY_THRIFT(thriftz ${thriftcppz_SOURCES})
-    TARGET_LINK_LIBRARIES_THRIFT(thriftz ${SYSLIBS} ${ZLIB_LIBRARIES})
-    TARGET_LINK_LIBRARIES_THRIFT_AGAINST_THRIFT_LIBRARY(thriftz thrift)
-endif()
-
-if(WITH_QT4)
-    set(CMAKE_AUTOMOC ON)
-    find_package(Qt4 REQUIRED COMPONENTS QtCore QtNetwork)
-    ADD_LIBRARY_THRIFT(thriftqt ${thriftcppqt_SOURCES})
-    TARGET_LINK_LIBRARIES_THRIFT(thriftqt ${SYSLIBS} Qt4::QtCore Qt4::QtNetwork)
-    TARGET_LINK_LIBRARIES_THRIFT_AGAINST_THRIFT_LIBRARY(thriftqt thrift)
-endif()
-
-if(WITH_QT5)
-    # Qt5 has its own directory to avoid conflict with Qt4 caused by CMAKE_AUTOMOC
-    add_subdirectory(src/thrift/qt)
-endif()
-
-if(MSVC)
-    add_definitions("-DUNICODE -D_UNICODE")
-endif()
-
-add_definitions("-D__STDC_LIMIT_MACROS")
-
-# Install the headers
-install(DIRECTORY "src/thrift" DESTINATION "${INCLUDE_INSTALL_DIR}"
-    FILES_MATCHING PATTERN "*.h" PATTERN "*.tcc")
-# Copy config.h file
-install(DIRECTORY "${CMAKE_BINARY_DIR}/thrift" DESTINATION "${INCLUDE_INSTALL_DIR}"
-    FILES_MATCHING PATTERN "*.h")
-
-if(BUILD_TESTING)
-    add_subdirectory(test)
-endif()

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/Makefile.am
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/Makefile.am b/depends/thirdparty/thrift/lib/cpp/Makefile.am
deleted file mode 100755
index 4742ee0..0000000
--- a/depends/thirdparty/thrift/lib/cpp/Makefile.am
+++ /dev/null
@@ -1,276 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements. See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership. The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License. You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied. See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-AUTOMAKE_OPTIONS = subdir-objects
-
-moc_%.cpp: %.h
-	$(QT_MOC) $(QT_CFLAGS) $< -o $@
-
-moc__%.cpp: %.h
-	$(QT5_MOC) $(QT5_CFLAGS) $< -o $@
-
-SUBDIRS = .
-
-if WITH_TESTS
-SUBDIRS += test
-endif
-
-pkgconfigdir = $(libdir)/pkgconfig
-
-lib_LTLIBRARIES = libthrift.la
-pkgconfig_DATA = thrift.pc
-libthrift_la_LDFLAGS = -release $(VERSION) $(BOOST_LDFLAGS) $(OPENSSL_LDFLAGS)
-
-## We only build the extra libraries if we have the dependencies,
-## but we install all of the headers unconditionally.
-if AMX_HAVE_LIBEVENT
-lib_LTLIBRARIES += libthriftnb.la
-pkgconfig_DATA += thrift-nb.pc
-endif
-if AMX_HAVE_ZLIB
-lib_LTLIBRARIES += libthriftz.la
-pkgconfig_DATA += thrift-z.pc
-endif
-if AMX_HAVE_QT
-lib_LTLIBRARIES += libthriftqt.la
-pkgconfig_DATA += thrift-qt.pc
-endif
-if AMX_HAVE_QT5
-lib_LTLIBRARIES += libthriftqt5.la
-pkgconfig_DATA += thrift-qt5.pc
-endif
-
-AM_CXXFLAGS = -Wall -Wextra -pedantic
-AM_CPPFLAGS = $(BOOST_CPPFLAGS) $(OPENSSL_INCLUDES) -I$(srcdir)/src -D__STDC_LIMIT_MACROS
-AM_LDFLAGS = $(BOOST_LDFLAGS) $(OPENSSL_LDFLAGS)
-
-# Define the source files for the module
-
-libthrift_la_SOURCES = src/thrift/TApplicationException.cpp \
-                       src/thrift/TOutput.cpp \
-                       src/thrift/VirtualProfiling.cpp \
-                       src/thrift/async/TAsyncChannel.cpp \
-                       src/thrift/async/TConcurrentClientSyncInfo.cpp \
-                       src/thrift/concurrency/ThreadManager.cpp \
-                       src/thrift/concurrency/TimerManager.cpp \
-                       src/thrift/concurrency/Util.cpp \
-                       src/thrift/processor/PeekProcessor.cpp \
-                       src/thrift/protocol/TDebugProtocol.cpp \
-                       src/thrift/protocol/TJSONProtocol.cpp \
-                       src/thrift/protocol/TBase64Utils.cpp \
-                       src/thrift/protocol/TMultiplexedProtocol.cpp \
-                       src/thrift/protocol/TProtocol.cpp \
-                       src/thrift/transport/TTransportException.cpp \
-                       src/thrift/transport/TFDTransport.cpp \
-                       src/thrift/transport/TFileTransport.cpp \
-                       src/thrift/transport/TSimpleFileTransport.cpp \
-                       src/thrift/transport/THttpTransport.cpp \
-                       src/thrift/transport/THttpClient.cpp \
-                       src/thrift/transport/THttpServer.cpp \
-                       src/thrift/transport/TSocket.cpp \
-                       src/thrift/transport/TPipe.cpp \
-                       src/thrift/transport/TPipeServer.cpp \
-                       src/thrift/transport/TSSLSocket.cpp \
-                       src/thrift/transport/TSocketPool.cpp \
-                       src/thrift/transport/TServerSocket.cpp \
-                       src/thrift/transport/TSSLServerSocket.cpp \
-                       src/thrift/transport/TTransportUtils.cpp \
-                       src/thrift/transport/TBufferTransports.cpp \
-                       src/thrift/server/TConnectedClient.cpp \
-                       src/thrift/server/TServer.cpp \
-                       src/thrift/server/TServerFramework.cpp \
-                       src/thrift/server/TSimpleServer.cpp \
-                       src/thrift/server/TThreadPoolServer.cpp \
-                       src/thrift/server/TThreadedServer.cpp
-
-if WITH_BOOSTTHREADS
-libthrift_la_SOURCES += src/thrift/concurrency/BoostThreadFactory.cpp \
-                        src/thrift/concurrency/BoostMonitor.cpp \
-                        src/thrift/concurrency/BoostMutex.cpp
-else
-libthrift_la_SOURCES += src/thrift/concurrency/Mutex.cpp \
-                        src/thrift/concurrency/Monitor.cpp \
-                        src/thrift/concurrency/PosixThreadFactory.cpp
-endif
-
-libthriftnb_la_SOURCES = src/thrift/server/TNonblockingServer.cpp \
-                         src/thrift/async/TAsyncProtocolProcessor.cpp \
-                         src/thrift/async/TEvhttpServer.cpp \
-                         src/thrift/async/TEvhttpClientChannel.cpp
-
-libthriftz_la_SOURCES = src/thrift/transport/TZlibTransport.cpp
-
-libthriftqt_la_MOC = src/thrift/qt/moc_TQTcpServer.cpp
-nodist_libthriftqt_la_SOURCES = $(libthriftqt_la_MOC)
-libthriftqt_la_SOURCES = src/thrift/qt/TQIODeviceTransport.cpp \
-                         src/thrift/qt/TQTcpServer.cpp
-CLEANFILES = $(libthriftqt_la_MOC)
-
-libthriftqt5_la_MOC = src/thrift/qt/moc__TQTcpServer.cpp
-nodist_libthriftqt5_la_SOURCES = $(libthriftqt5_la_MOC)
-libthriftqt5_la_SOURCES = src/thrift/qt/TQIODeviceTransport.cpp \
-                          src/thrift/qt/TQTcpServer.cpp
-CLEANFILES += $(libthriftqt5_la_MOC)
-
-# Flags for the various libraries
-libthriftnb_la_CPPFLAGS = $(AM_CPPFLAGS) $(LIBEVENT_CPPFLAGS)
-libthriftz_la_CPPFLAGS  = $(AM_CPPFLAGS) $(ZLIB_CPPFLAGS)
-libthriftqt_la_CPPFLAGS = $(AM_CPPFLAGS) $(QT_CFLAGS)
-libthriftqt5_la_CPPFLAGS = $(AM_CPPFLAGS) $(QT5_CFLAGS)
-if QT5_REDUCE_RELOCATIONS
-libthriftqt5_la_CPPFLAGS += -fPIC
-endif
-libthriftnb_la_CXXFLAGS = $(AM_CXXFLAGS)
-libthriftz_la_CXXFLAGS  = $(AM_CXXFLAGS)
-libthriftqt_la_CXXFLAGS  = $(AM_CXXFLAGS)
-libthriftqt5_la_CXXFLAGS  = $(AM_CXXFLAGS)
-libthriftnb_la_LDFLAGS  = -release $(VERSION) $(BOOST_LDFLAGS)
-libthriftz_la_LDFLAGS   = -release $(VERSION) $(BOOST_LDFLAGS)
-libthriftqt_la_LDFLAGS   = -release $(VERSION) $(BOOST_LDFLAGS) $(QT_LIBS)
-libthriftqt5_la_LDFLAGS   = -release $(VERSION) $(BOOST_LDFLAGS) $(QT5_LIBS)
-
-include_thriftdir = $(includedir)/thrift
-include_thrift_HEADERS = \
-                         $(top_builddir)/config.h \
-                         src/thrift/thrift-config.h \
-                         src/thrift/TDispatchProcessor.h \
-                         src/thrift/Thrift.h \
-                         src/thrift/TOutput.h \
-                         src/thrift/TProcessor.h \
-                         src/thrift/TApplicationException.h \
-                         src/thrift/TLogging.h \
-                         src/thrift/cxxfunctional.h \
-                         src/thrift/TToString.h
-
-include_concurrencydir = $(include_thriftdir)/concurrency
-include_concurrency_HEADERS = \
-                         src/thrift/concurrency/BoostThreadFactory.h \
-                         src/thrift/concurrency/Exception.h \
-                         src/thrift/concurrency/Mutex.h \
-                         src/thrift/concurrency/Monitor.h \
-                         src/thrift/concurrency/PlatformThreadFactory.h \
-                         src/thrift/concurrency/PosixThreadFactory.h \
-                         src/thrift/concurrency/StdMonitor.cpp \
-                         src/thrift/concurrency/StdMutex.cpp \
-                         src/thrift/concurrency/StdThreadFactory.cpp \
-                         src/thrift/concurrency/StdThreadFactory.h \
-                         src/thrift/concurrency/Thread.h \
-                         src/thrift/concurrency/ThreadManager.h \
-                         src/thrift/concurrency/TimerManager.h \
-                         src/thrift/concurrency/FunctionRunner.h \
-                         src/thrift/concurrency/Util.h
-
-include_protocoldir = $(include_thriftdir)/protocol
-include_protocol_HEADERS = \
-                         src/thrift/protocol/TBinaryProtocol.h \
-                         src/thrift/protocol/TBinaryProtocol.tcc \
-                         src/thrift/protocol/TCompactProtocol.h \
-                         src/thrift/protocol/TCompactProtocol.tcc \
-                         src/thrift/protocol/TDebugProtocol.h \
-                         src/thrift/protocol/TBase64Utils.h \
-                         src/thrift/protocol/TJSONProtocol.h \
-                         src/thrift/protocol/TMultiplexedProtocol.h \
-                         src/thrift/protocol/TProtocolDecorator.h \
-                         src/thrift/protocol/TProtocolTap.h \
-                         src/thrift/protocol/TProtocolException.h \
-                         src/thrift/protocol/TVirtualProtocol.h \
-                         src/thrift/protocol/TProtocol.h
-
-include_transportdir = $(include_thriftdir)/transport
-include_transport_HEADERS = \
-                         src/thrift/transport/PlatformSocket.h \
-                         src/thrift/transport/TFDTransport.h \
-                         src/thrift/transport/TFileTransport.h \
-                         src/thrift/transport/TSimpleFileTransport.h \
-                         src/thrift/transport/TServerSocket.h \
-                         src/thrift/transport/TSSLServerSocket.h \
-                         src/thrift/transport/TServerTransport.h \
-                         src/thrift/transport/THttpTransport.h \
-                         src/thrift/transport/THttpClient.h \
-                         src/thrift/transport/THttpServer.h \
-                         src/thrift/transport/TSocket.h \
-                         src/thrift/transport/TPipe.h \
-                         src/thrift/transport/TPipeServer.h \
-                         src/thrift/transport/TSSLSocket.h \
-                         src/thrift/transport/TSocketPool.h \
-                         src/thrift/transport/TVirtualTransport.h \
-                         src/thrift/transport/TTransport.h \
-                         src/thrift/transport/TTransportException.h \
-                         src/thrift/transport/TTransportUtils.h \
-                         src/thrift/transport/TBufferTransports.h \
-                         src/thrift/transport/TShortReadTransport.h \
-                         src/thrift/transport/TZlibTransport.h
-
-include_serverdir = $(include_thriftdir)/server
-include_server_HEADERS = \
-                         src/thrift/server/TConnectedClient.h \
-                         src/thrift/server/TServer.h \
-                         src/thrift/server/TServerFramework.h \
-                         src/thrift/server/TSimpleServer.h \
-                         src/thrift/server/TThreadPoolServer.h \
-                         src/thrift/server/TThreadedServer.h \
-                         src/thrift/server/TNonblockingServer.h
-
-include_processordir = $(include_thriftdir)/processor
-include_processor_HEADERS = \
-                         src/thrift/processor/PeekProcessor.h \
-                         src/thrift/processor/StatsProcessor.h \
-                         src/thrift/processor/TMultiplexedProcessor.h
-
-include_asyncdir = $(include_thriftdir)/async
-include_async_HEADERS = \
-                     src/thrift/async/TAsyncChannel.h \
-                     src/thrift/async/TAsyncDispatchProcessor.h \
-                     src/thrift/async/TAsyncProcessor.h \
-                     src/thrift/async/TAsyncBufferProcessor.h \
-                     src/thrift/async/TAsyncProtocolProcessor.h \
-                     src/thrift/async/TConcurrentClientSyncInfo.h \
-                     src/thrift/async/TEvhttpClientChannel.h \
-                     src/thrift/async/TEvhttpServer.h
-
-include_qtdir = $(include_thriftdir)/qt
-include_qt_HEADERS = \
-                  src/thrift/qt/TQIODeviceTransport.h \
-                  src/thrift/qt/TQTcpServer.h
-
-THRIFT = $(top_builddir)/compiler/cpp/thrift
-
-WINDOWS_DIST = \
-             src/thrift/windows \
-             thrift.sln \
-             libthrift.vcxproj \
-             libthrift.vcxproj.filters \
-             libthriftnb.vcxproj \
-             libthriftnb.vcxproj.filters \
-             3rdparty.props
-
-EXTRA_DIST = \
-             CMakeLists.txt \
-             coding_standards.md \
-             README.md \
-             thrift-nb.pc.in \
-             thrift.pc.in \
-             thrift-z.pc.in \
-             thrift-qt.pc.in \
-             thrift-qt5.pc.in \
-             src/thrift/qt/CMakeLists.txt \
-             $(WINDOWS_DIST)
-
-style-local:
-	$(CPPSTYLE_CMD)

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/README.md
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/README.md b/depends/thirdparty/thrift/lib/cpp/README.md
deleted file mode 100755
index 2bee2ec..0000000
--- a/depends/thirdparty/thrift/lib/cpp/README.md
+++ /dev/null
@@ -1,274 +0,0 @@
-Thrift C++ Software Library
-
-# License
-
-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.
-
-
-# Using Thrift with C++
-
-The Thrift C++ libraries are built using the GNU tools. Follow the instructions
-in the top-level README.md
-
-In case you do not want to open another README.md file, do this thrift src:
-
-    ./bootstrap.sh
-    ./configure (--with-boost=/usr/local)
-    make
-    sudo make install
-
-Thrift is divided into two libraries.
-
-* libthrift - The core Thrift library contains all the core Thrift code. It requires
-  boost shared pointers, pthreads, and librt.
-
-* libthriftnb - This library contains the Thrift nonblocking server, which uses libevent.
-  To link this library you will also need to link libevent.
-
-## Linking Against Thrift
-
-After you build and install Thrift the libraries are installed to
-/usr/local/lib by default. Make sure this is in your LDPATH.
-
-On Linux, the best way to do this is to ensure that /usr/local/lib is in
-your /etc/ld.so.conf and then run /sbin/ldconfig.
-
-Depending upon whether you are linking dynamically or statically and how
-your build environment it set up, you may need to include additional
-libraries when linking against thrift, such as librt and/or libpthread. If
-you are using libthriftnb you will also need libevent.
-
-## Dependencies
-
-boost shared pointers
-http://www.boost.org/libs/smart_ptr/smart_ptr.htm
-
-libevent (for libthriftnb only)
-http://monkey.org/~provos/libevent/
-
-# Using Thrift with C++ on Windows
-
-You need to define an environment variables for 3rd party components separately:
-
-BOOST_ROOT : For boost, e.g. D:\boost_1_55_0
-OPENSSL_ROOT_DIR : For OpenSSL, e.g. D:\OpenSSL-Win32
-
-only required by libthriftnb:
-
-LIBEVENT_ROOT_DIR : For Libevent e.g. D:\libevent-2.0.21-stable
-
-See /3rdparty.user for more details.
-
-Thrift is divided into two libraries.
-
-* libthrift - The core Thrift library contains all the core Thrift code. It requires
-  boost shared pointers, pthreads, and librt.
-
-* libthriftnb - This library contains the Thrift nonblocking server, which uses libevent.
-  To link this library you will also need to link libevent.
-
-## Linking Against Thrift
-
-You need to link your project that uses thrift against all the thrift
-dependencies; in the case of libthrift, boost and for
-libthriftnb, libevent.
-
-In the project properties you must also set HAVE_CONFIG_H as force include
-the config header: "windows/confg.h"
-
-## Dependencies
-
-boost shared pointers
-http://www.boost.org/libs/smart_ptr/smart_ptr.htm
-
-boost thread
-http://www.boost.org/doc/libs/release/doc/html/thread.html
-
-libevent (for libthriftnb only)
-http://monkey.org/~provos/libevent/
-
-## Notes on boost thread (static vs shared):
-
-By default lib/cpp/windows/force_inc.h defines:
-
-    #define BOOST_ALL_NO_LIB 1
-    #define BOOST_THREAD_NO_LIB 1
-
-This has for effect to have the host application linking against Thrift
-to have to link with boost thread as a static library.
-
-If you wanted instead to link with boost thread as a shared library,
-you'll need to uncomment those two lines, and recompile.
-
-## Windows version compatibility
-
-The Thrift library targets Windows XP for broadest compatbility. A notable
-difference is in the Windows-specific implementation of the socket poll
-function. To target Vista, Win7 or other versions, comment out the line
-
-    #define TARGET_WIN_XP.
-
-## Named Pipes
-
-Named Pipe transport has been added in the TPipe and TPipeServer classes. This
-is currently Windows-only. Named pipe transport for *NIX has not been
-implemented. Domain sockets are a better choice for local IPC under non-Windows
-OS's. *NIX named pipes only support 1:1 client-server connection.
-
-# Thrift/SSL
-
-## Scope
-
-This SSL only supports blocking mode socket I/O. It can only be used with
-TSimpleServer, TThreadedServer, and TThreadPoolServer.
-
-## Implementation
-
-There're two main classes TSSLSocketFactory and TSSLSocket. Instances of
-TSSLSocket are always created from TSSLSocketFactory.
-
-PosixSSLThreadFactory creates PosixSSLThread. The only difference from the
-PthreadThread type is that it cleanups OpenSSL error queue upon exiting
-the thread. Ideally, OpenSSL APIs should only be called from PosixSSLThread.
-
-## How to use SSL APIs
-
-This is for demo. In real code, typically only one TSSLSocketFactory
-instance is needed.
-
-    shared_ptr<TSSLSocketFactory> getSSLSocketFactory() {
-      shared_ptr<TSSLSocketFactory> factory(new TSSLSocketFactory());
-      // client: load trusted certificates
-      factory->loadTrustedCertificates("my-trusted-ca-certificates.pem");
-      // client: optionally set your own access manager, otherwise,
-      //         the default client access manager will be loaded.
-
-      factory->loadCertificate("my-certificate-signed-by-ca.pem");
-      factory->loadPrivateKey("my-private-key.pem");
-      // server: optionally setup access manager
-      // shared_ptr<AccessManager> accessManager(new MyAccessManager);
-      // factory->access(accessManager);
-      ...
-    }
-
-
-client code sample
-
-    shared_ptr<TSSLSocketFactory> factory = getSSLSocketFactory();
-    shared_ptr<TSocket> socket = factory.createSocket(host, port);
-    shared_ptr<TBufferedTransport> transport(new TBufferedTransport(socket));
-    ...
-
-
-server code sample
-
-    shared_ptr<TSSLSocketFactory> factory = getSSLSocketFactory();
-    shared_ptr<TSSLServerSocket> socket(new TSSLServerSocket(port, factory));
-    shared_ptr<TTransportFactory> transportFactory(new TBufferedTransportFactory));
-    ...
-
-## AccessManager
-
-AccessManager defines a callback interface. It has three callback methods:
-
-(a) Decision verify(const sockaddr_storage& sa);
-
-(b) Decision verify(const string& host, const char* name, int size);
-
-(c) Decision verify(const sockaddr_storage& sa, const char* data, int size);
-
-After SSL handshake completes, additional checks are conducted. Application
-is given the chance to decide whether or not to continue the conversation
-with the remote. Application is queried through the above three "verify"
-method. They are called at different points of the verification process.
-
-Decisions can be one of ALLOW, DENY, and SKIP. ALLOW and DENY means the
-conversation should be continued or disconnected, respectively. ALLOW and
-DENY decision stops the verification process. SKIP means there's no decision
-based on the given input, continue the verification process.
-
-First, (a) is called with the remote IP. It is called once at the beginning.
-"sa" is the IP address of the remote peer.
-
-Then, the certificate of remote peer is loaded. SubjectAltName extensions
-are extracted and sent to application for verification. When a DNS
-subjectAltName field is extracted, (b) is called. When an IP subjectAltName
-field is extracted, (c) is called.
-
-The "host" in (b) is the value from TSocket::getHost() if this is a client
-side socket, or TSocket::getPeerHost() if this is a server side socket. The
-reason is client side socket initiates the connection. TSocket::getHost()
-is the remote host name. On server side, the remote host name is unknown
-unless it's retrieved through TSocket::getPeerHost(). Either way, "host"
-should be the remote host name. Keep in mind, if TSocket::getPeerHost()
-failed, it would return the remote host name in numeric format.
-
-If all subjectAltName extensions were "skipped", the common name field would
-be checked. It is sent to application through (c), where "sa" is the remote
-IP address. "data" is the IP address extracted from subjectAltName IP
-extension, and "size" is the length of the extension data.
-
-If any of the above "verify" methods returned a decision ALLOW or DENY, the
-verification process would be stopped.
-
-If any of the above "verify" methods returned SKIP, that decision would be
-ignored and the verification process would move on till the last item is
-examined. At that point, if there's still no decision, the connection is
-terminated.
-
-Thread safety, an access manager should not store state information if it's
-to be used by many SSL sockets.
-
-## SIGPIPE signal
-
-Applications running OpenSSL over network connections may crash if SIGPIPE
-is not ignored. This happens when they receive a connection reset by remote
-peer exception, which somehow triggers a SIGPIPE signal. If not handled,
-this signal would kill the application.
-
-## How to run test client/server in SSL mode
-
-The server and client expects the followings from the directory /test/
-
-- keys/server.crt
-- keys/server.key
-- keys/CA.pem
-
-The file names are hard coded in the source code. You need to create these
-certificates before you can run the test code in SSL mode. Make sure at least
-one of the followings is included in "keys/server.crt",
-
-- subjectAltName, DNS localhost
-- subjectAltName, IP  127.0.0.1
-- common name,    localhost
-
-Run within /test/ folder,
-
-         ./cpp/TestServer --ssl &
-         ./cpp/TestClient --ssl
-
-If "-h <host>" is used to run client, the above "localhost" in the above
-keys/server.crt has to be replaced with that host name.
-
-## TSSLSocketFactory::randomize()
-
-The default implementation of OpenSSLSocketFactory::randomize() simply calls
-OpenSSL's RAND_poll() when OpenSSL library is first initialized.
-
-The PRNG seed is key to the application security. This method should be
-overridden if it's not strong enough for you.

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/coding_standards.md
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/coding_standards.md b/depends/thirdparty/thrift/lib/cpp/coding_standards.md
deleted file mode 100644
index 8018c77..0000000
--- a/depends/thirdparty/thrift/lib/cpp/coding_standards.md
+++ /dev/null
@@ -1,4 +0,0 @@
-Please follow [General Coding Standards](/doc/coding_standards.md)
-
- * see .clang-format in root dir for settings of accepted format
- * clang-format (3.5 or newer) can be used to automaticaly reformat code ('make style' command)

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj b/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj
deleted file mode 100644
index b4f1c50..0000000
--- a/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj
+++ /dev/null
@@ -1,359 +0,0 @@
-\ufeff<?xml version="1.0" encoding="utf-8"?>
-<Project DefaultTargets="Build" ToolsVersion="4.0" xmlns="http://schemas.microsoft.com/developer/msbuild/2003">
-  <ItemGroup Label="ProjectConfigurations">
-    <ProjectConfiguration Include="Debug-mt|Win32">
-      <Configuration>Debug-mt</Configuration>
-      <Platform>Win32</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Debug-mt|x64">
-      <Configuration>Debug-mt</Configuration>
-      <Platform>x64</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Debug|Win32">
-      <Configuration>Debug</Configuration>
-      <Platform>Win32</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Debug|x64">
-      <Configuration>Debug</Configuration>
-      <Platform>x64</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Release-mt|Win32">
-      <Configuration>Release-mt</Configuration>
-      <Platform>Win32</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Release-mt|x64">
-      <Configuration>Release-mt</Configuration>
-      <Platform>x64</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Release|Win32">
-      <Configuration>Release</Configuration>
-      <Platform>Win32</Platform>
-    </ProjectConfiguration>
-    <ProjectConfiguration Include="Release|x64">
-      <Configuration>Release</Configuration>
-      <Platform>x64</Platform>
-    </ProjectConfiguration>
-  </ItemGroup>
-  <ItemGroup>
-    <ClCompile Include="src\thrift\async\TAsyncChannel.cpp"/>
-    <ClCompile Include="src\thrift\concurrency\BoostMonitor.cpp" />
-    <ClCompile Include="src\thrift\concurrency\BoostMutex.cpp" />
-    <ClCompile Include="src\thrift\concurrency\BoostThreadFactory.cpp" />
-    <ClCompile Include="src\thrift\concurrency\StdThreadFactory.cpp" />
-    <ClCompile Include="src\thrift\concurrency\ThreadManager.cpp"/>
-    <ClCompile Include="src\thrift\concurrency\TimerManager.cpp"/>
-    <ClCompile Include="src\thrift\concurrency\Util.cpp"/>
-    <ClCompile Include="src\thrift\processor\PeekProcessor.cpp"/>
-    <ClCompile Include="src\thrift\protocol\TBase64Utils.cpp" />
-    <ClCompile Include="src\thrift\protocol\TDebugProtocol.cpp"/>
-    <ClCompile Include="src\thrift\protocol\TJSONProtocol.cpp"/>
-    <ClCompile Include="src\thrift\protocol\TMultiplexedProtocol.cpp"/>
-    <ClCompile Include="src\thrift\server\TSimpleServer.cpp"/>
-    <ClCompile Include="src\thrift\server\TThreadPoolServer.cpp"/>
-    <ClCompile Include="src\thrift\server\TThreadedServer.cpp"/>
-    <ClCompile Include="src\thrift\TApplicationException.cpp"/>
-    <ClCompile Include="src\thrift\Thrift.cpp"/>
-    <ClCompile Include="src\thrift\transport\TBufferTransports.cpp"/>
-    <ClCompile Include="src\thrift\transport\TFDTransport.cpp" />
-    <ClCompile Include="src\thrift\transport\THttpClient.cpp" />
-    <ClCompile Include="src\thrift\transport\THttpServer.cpp" />
-    <ClCompile Include="src\thrift\transport\THttpTransport.cpp"/>
-    <ClCompile Include="src\thrift\transport\TPipe.cpp" />
-    <ClCompile Include="src\thrift\transport\TPipeServer.cpp" />
-    <ClCompile Include="src\thrift\transport\TServerSocket.cpp"/>
-    <ClCompile Include="src\thrift\transport\TSimpleFileTransport.cpp" />
-    <ClCompile Include="src\thrift\transport\TFileTransport.cpp" />
-    <ClCompile Include="src\thrift\transport\TSocket.cpp"/>
-    <ClCompile Include="src\thrift\transport\TSSLSocket.cpp"/>
-    <ClCompile Include="src\thrift\transport\TTransportException.cpp"/>
-    <ClCompile Include="src\thrift\transport\TTransportUtils.cpp"/>
-    <ClCompile Include="src\thrift\windows\GetTimeOfDay.cpp" />
-    <ClCompile Include="src\thrift\windows\OverlappedSubmissionThread.cpp" />
-    <ClCompile Include="src\thrift\windows\SocketPair.cpp" />
-    <ClCompile Include="src\thrift\windows\TWinsockSingleton.cpp" />
-    <ClCompile Include="src\thrift\windows\WinFcntl.cpp" />
-  </ItemGroup>
-  <ItemGroup>
-    <ClInclude Include="src\thrift\async\TAsyncChannel.h" />
-    <ClInclude Include="src\thrift\concurrency\BoostThreadFactory.h" />
-    <ClInclude Include="src\thrift\concurrency\StdThreadFactory.h" />
-    <ClInclude Include="src\thrift\concurrency\Exception.h" />
-    <ClInclude Include="src\thrift\concurrency\PlatformThreadFactory.h" />
-    <ClInclude Include="src\thrift\processor\PeekProcessor.h" />
-    <ClInclude Include="src\thrift\processor\TMultiplexedProcessor.h" />
-    <ClInclude Include="src\thrift\protocol\TBinaryProtocol.h" />
-    <ClInclude Include="src\thrift\protocol\TDebugProtocol.h" />
-    <ClInclude Include="src\thrift\protocol\TJSONProtocol.h" />
-    <ClInclude Include="src\thrift\protocol\TMultiplexedProtocol.h" />
-    <ClInclude Include="src\thrift\protocol\TProtocol.h" />
-    <ClInclude Include="src\thrift\protocol\TVirtualProtocol.h" />
-    <ClInclude Include="src\thrift\server\TServer.h" />
-    <ClInclude Include="src\thrift\server\TSimpleServer.h" />
-    <ClInclude Include="src\thrift\server\TThreadPoolServer.h" />
-    <ClInclude Include="src\thrift\server\TThreadedServer.h" />
-    <ClInclude Include="src\thrift\TApplicationException.h" />
-    <ClInclude Include="src\thrift\Thrift.h" />
-    <ClInclude Include="src\thrift\TProcessor.h" />
-    <ClInclude Include="src\thrift\transport\TBufferTransports.h" />
-    <ClInclude Include="src\thrift\transport\TFDTransport.h" />
-    <ClInclude Include="src\thrift\transport\TFileTransport.h" />
-    <ClInclude Include="src\thrift\transport\THttpClient.h" />
-    <ClInclude Include="src\thrift\transport\THttpServer.h" />
-    <ClInclude Include="src\thrift\transport\TPipe.h" />
-    <ClInclude Include="src\thrift\transport\TPipeServer.h" />
-    <ClInclude Include="src\thrift\transport\TServerSocket.h" />
-    <ClInclude Include="src\thrift\transport\TServerTransport.h" />
-    <ClInclude Include="src\thrift\transport\TSimpleFileTransport.h" />
-    <ClInclude Include="src\thrift\transport\TSocket.h" />
-    <ClInclude Include="src\thrift\transport\TSSLSocket.h" />
-    <ClInclude Include="src\thrift\transport\TTransport.h" />
-    <ClInclude Include="src\thrift\transport\TTransportException.h" />
-    <ClInclude Include="src\thrift\transport\TTransportUtils.h" />
-    <ClInclude Include="src\thrift\transport\TVirtualTransport.h" />
-    <ClInclude Include="src\thrift\windows\config.h" />
-    <ClInclude Include="src\thrift\windows\GetTimeOfDay.h" />
-    <ClInclude Include="src\thrift\windows\Operators.h" />
-    <ClInclude Include="src\thrift\windows\OverlappedSubmissionThread.h" />
-    <ClInclude Include="src\thrift\windows\SocketPair.h" />
-    <ClInclude Include="src\thrift\windows\TWinsockSingleton.h" />
-    <ClInclude Include="src\thrift\windows\WinFcntl.h" />
-  </ItemGroup>
-  <ItemGroup>
-    <None Include="src\thrift\protocol\TBinaryProtocol.tcc" />
-  </ItemGroup>
-  <PropertyGroup Label="Globals">
-    <ProjectGuid>{DD26F57E-60F2-4F37-A616-D219A9BF338F}</ProjectGuid>
-    <Keyword>Win32Proj</Keyword>
-    <RootNamespace>thrift</RootNamespace>
-    <ProjectName>libthrift</ProjectName>
-  </PropertyGroup>
-  <Import Project="$(VCTargetsPath)\Microsoft.Cpp.Default.props" />
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>true</UseDebugLibraries>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|Win32'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>true</UseDebugLibraries>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>true</UseDebugLibraries>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|x64'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>true</UseDebugLibraries>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|Win32'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>false</UseDebugLibraries>
-    <WholeProgramOptimization>true</WholeProgramOptimization>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|Win32'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>false</UseDebugLibraries>
-    <WholeProgramOptimization>true</WholeProgramOptimization>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>false</UseDebugLibraries>
-    <WholeProgramOptimization>true</WholeProgramOptimization>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|x64'" Label="Configuration">
-    <ConfigurationType>StaticLibrary</ConfigurationType>
-    <UseDebugLibraries>false</UseDebugLibraries>
-    <WholeProgramOptimization>true</WholeProgramOptimization>
-    <CharacterSet>MultiByte</CharacterSet>
-  </PropertyGroup>
-  <Import Project="$(VCTargetsPath)\Microsoft.Cpp.props" />
-  <ImportGroup Label="ExtensionSettings">
-  </ImportGroup>
-  <ImportGroup Label="PropertySheets" Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|Win32'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|x64'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Label="PropertySheets" Condition="'$(Configuration)|$(Platform)'=='Release|Win32'">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|Win32'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <ImportGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|x64'" Label="PropertySheets">
-    <Import Project="$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props" Condition="exists('$(UserRootDir)\Microsoft.Cpp.$(Platform).user.props')" Label="LocalAppDataPlatform" />
-    <Import Project="3rdparty.props" />
-  </ImportGroup>
-  <PropertyGroup Label="UserMacros" />
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|Win32'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|x64'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|Win32'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|Win32'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <PropertyGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|x64'">
-    <IncludePath>$(ProjectDir)\src\;$(ProjectDir)\src\thrift\windows\;$(BOOST_ROOT)\include;$(BOOST_ROOT)\;$(OPENSSL_ROOT_DIR)\include\;$(IncludePath)</IncludePath>
-  </PropertyGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Debug|Win32'">
-    <ClCompile>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <WarningLevel>Level3</WarningLevel>
-      <Optimization>Disabled</Optimization>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;_DEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <ProgramDataBaseFileName>$(IntDir)libthrift.pdb</ProgramDataBaseFileName>
-      <RuntimeLibrary>MultiThreadedDebugDLL</RuntimeLibrary>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|Win32'">
-    <ClCompile>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <WarningLevel>Level3</WarningLevel>
-      <Optimization>Disabled</Optimization>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;_DEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <ProgramDataBaseFileName>$(IntDir)libthrift.pdb</ProgramDataBaseFileName>
-      <RuntimeLibrary>MultiThreadedDebug</RuntimeLibrary>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Debug|x64'">
-    <ClCompile>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <WarningLevel>Level3</WarningLevel>
-      <Optimization>Disabled</Optimization>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;_DEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Debug-mt|x64'">
-    <ClCompile>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <WarningLevel>Level3</WarningLevel>
-      <Optimization>Disabled</Optimization>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;_DEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <RuntimeLibrary>MultiThreadedDebug</RuntimeLibrary>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Release|Win32'">
-    <ClCompile>
-      <WarningLevel>Level3</WarningLevel>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <Optimization>MaxSpeed</Optimization>
-      <FunctionLevelLinking>true</FunctionLevelLinking>
-      <IntrinsicFunctions>true</IntrinsicFunctions>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;NDEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <ProgramDataBaseFileName>$(IntDir)libthrift.pdb</ProgramDataBaseFileName>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-      <EnableCOMDATFolding>true</EnableCOMDATFolding>
-      <OptimizeReferences>true</OptimizeReferences>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|Win32'">
-    <ClCompile>
-      <WarningLevel>Level3</WarningLevel>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <Optimization>MaxSpeed</Optimization>
-      <FunctionLevelLinking>true</FunctionLevelLinking>
-      <IntrinsicFunctions>true</IntrinsicFunctions>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;NDEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <ProgramDataBaseFileName>$(IntDir)libthrift.pdb</ProgramDataBaseFileName>
-      <RuntimeLibrary>MultiThreaded</RuntimeLibrary>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-      <EnableCOMDATFolding>true</EnableCOMDATFolding>
-      <OptimizeReferences>true</OptimizeReferences>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Release|x64'">
-    <ClCompile>
-      <WarningLevel>Level3</WarningLevel>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <Optimization>MaxSpeed</Optimization>
-      <FunctionLevelLinking>true</FunctionLevelLinking>
-      <IntrinsicFunctions>true</IntrinsicFunctions>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;NDEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-      <EnableCOMDATFolding>true</EnableCOMDATFolding>
-      <OptimizeReferences>true</OptimizeReferences>
-    </Link>
-  </ItemDefinitionGroup>
-  <ItemDefinitionGroup Condition="'$(Configuration)|$(Platform)'=='Release-mt|x64'">
-    <ClCompile>
-      <WarningLevel>Level3</WarningLevel>
-      <PrecompiledHeader>NotUsing</PrecompiledHeader>
-      <Optimization>MaxSpeed</Optimization>
-      <FunctionLevelLinking>true</FunctionLevelLinking>
-      <IntrinsicFunctions>true</IntrinsicFunctions>
-      <PreprocessorDefinitions>HAVE_CONFIG_H=1;WIN32;NDEBUG;_LIB;%(PreprocessorDefinitions)</PreprocessorDefinitions>
-      <RuntimeLibrary>MultiThreaded</RuntimeLibrary>
-    </ClCompile>
-    <Link>
-      <SubSystem>Windows</SubSystem>
-      <GenerateDebugInformation>true</GenerateDebugInformation>
-      <EnableCOMDATFolding>true</EnableCOMDATFolding>
-      <OptimizeReferences>true</OptimizeReferences>
-    </Link>
-  </ItemDefinitionGroup>
-  <Import Project="$(VCTargetsPath)\Microsoft.Cpp.targets" />
-  <ImportGroup Label="ExtensionTargets">
-  </ImportGroup>
-</Project>

http://git-wip-us.apache.org/repos/asf/incubator-hawq/blob/928eade3/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj.filters
----------------------------------------------------------------------
diff --git a/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj.filters b/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj.filters
deleted file mode 100644
index ec21886..0000000
--- a/depends/thirdparty/thrift/lib/cpp/libthrift.vcxproj.filters
+++ /dev/null
@@ -1,277 +0,0 @@
-\ufeff<?xml version="1.0" encoding="utf-8"?>
-<Project ToolsVersion="4.0" xmlns="http://schemas.microsoft.com/developer/msbuild/2003">
-  <ItemGroup>
-    <ClCompile Include="src\thrift\transport\TBufferTransports.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\Thrift.cpp" />
-    <ClCompile Include="src\thrift\TApplicationException.cpp" />
-    <ClCompile Include="src\thrift\windows\StdAfx.cpp">
-      <Filter>windows</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TTransportException.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\windows\GetTimeOfDay.cpp">
-      <Filter>windows</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\ThreadManager.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\TimerManager.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\Util.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\protocol\TDebugProtocol.cpp">
-      <Filter>protocol</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\protocol\TBase64Utils.cpp">
-      <Filter>protocol</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\protocol\TJSONProtocol.cpp">
-      <Filter>protocol</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\protocol\TMultiplexedProtocol.cpp">
-      <Filter>protocol</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TFDTransport.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TFileTransport.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TSimpleFileTransport.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\THttpTransport.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\THttpClient.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\THttpServer.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TSSLSocket.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TTransportUtils.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\server\TSimpleServer.cpp">
-      <Filter>server</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\server\TThreadPoolServer.cpp">
-      <Filter>server</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\server\TThreadedServer.cpp">
-      <Filter>server</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\async\TAsyncChannel.cpp">
-      <Filter>async</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\processor\PeekProcessor.cpp">
-      <Filter>processor</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TServerSocket.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TSocket.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\windows\TWinsockSingleton.cpp">
-      <Filter>windows</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\windows\SocketPair.cpp">
-      <Filter>windows</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\BoostMonitor.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\BoostMutex.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\BoostThreadFactory.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\concurrency\StdThreadFactory.cpp">
-      <Filter>concurrency</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\windows\WinFcntl.cpp">
-      <Filter>windows</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TPipe.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-    <ClCompile Include="src\thrift\transport\TPipeServer.cpp">
-      <Filter>transport</Filter>
-    </ClCompile>
-  </ItemGroup>
-  <ItemGroup>
-    <ClInclude Include="src\thrift\transport\TBufferTransports.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TSocket.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TBinaryProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\Thrift.h" />
-    <ClInclude Include="src\thrift\TProcessor.h" />
-    <ClInclude Include="src\thrift\TApplicationException.h" />
-    <ClInclude Include="src\thrift\windows\StdAfx.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\TargetVersion.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\concurrency\Exception.h">
-      <Filter>concurrency</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TVirtualTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TTransportException.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\GetTimeOfDay.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TServerTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\config.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TVirtualProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\server\TServer.h">
-      <Filter>server</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\server\TSimpleServer.h">
-      <Filter>server</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\server\TThreadPoolServer.h">
-      <Filter>server</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\server\TThreadedServer.h">
-      <Filter>server</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\async\TAsyncChannel.h">
-      <Filter>async</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\processor\PeekProcessor.h">
-      <Filter>processor</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\processor\TMultiplexedProcessor.h">
-      <Filter>processor</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TFDTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TFileTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\THttpClient.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\THttpServer.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TSSLSocket.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TTransportUtils.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TSimpleFileTransport.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TJSONProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TMultiplexedProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\protocol\TDebugProtocol.h">
-      <Filter>protocol</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TServerSocket.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\Operators.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\TWinsockSingleton.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\SocketPair.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\force_inc.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\concurrency\BoostThreadFactory.h">
-      <Filter>concurrency</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\concurrency\StdThreadFactory.h">
-      <Filter>concurrency</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\concurrency\PlatformThreadFactory.h">
-      <Filter>concurrency</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\windows\WinFcntl.h">
-      <Filter>windows</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TPipe.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-    <ClInclude Include="src\thrift\transport\TPipeServer.h">
-      <Filter>transport</Filter>
-    </ClInclude>
-  </ItemGroup>
-  <ItemGroup>
-    <Filter Include="protocol">
-      <UniqueIdentifier>{07ced19b-b72a-4105-9ffb-6d2bcf64497e}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="transport">
-      <UniqueIdentifier>{e9f61404-1148-4103-bd6f-e5869d37fa79}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="windows">
-      <UniqueIdentifier>{2814002a-3c68-427e-b0eb-33acd2f406ae}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="concurrency">
-      <UniqueIdentifier>{addd4707-dbaa-4d0c-bef6-fff8be7b495a}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="server">
-      <UniqueIdentifier>{f55a8e9b-6959-487f-a396-c31b4d6c61d6}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="async">
-      <UniqueIdentifier>{d526885b-1b3e-4ee3-8027-e694fe98ad63}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="processor">
-      <UniqueIdentifier>{8f428da8-5a83-44fb-9578-de935fb415e1}</UniqueIdentifier>
-    </Filter>
-    <Filter Include="windows\tr1">
-      <UniqueIdentifier>{eea10406-3380-4f2d-9365-c26fa2875dae}</UniqueIdentifier>
-    </Filter>
-  </ItemGroup>
-  <ItemGroup>
-    <None Include="src\thrift\protocol\TBinaryProtocol.tcc">
-      <Filter>protocol</Filter>
-    </None>
-    <None Include="src\thrift\windows\tr1\functional">
-      <Filter>windows\tr1</Filter>
-    </None>
-  </ItemGroup>
-</Project>