You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by di...@apache.org on 2015/10/23 22:08:37 UTC

[12/16] incubator-geode git commit: From: Niall Pemberton Date: Sat, 17 Oct 2015 12:34:12 +0100 Subject: [PATCH 1/2] Remove Pivotal/VMWare/AsIs License and add ASF License Header File: 0003-Remove-Pivotal-VMWare-AsIs-License-and-add-A

From: Niall Pemberton <ni...@apache.org>
Date: Sat, 17 Oct 2015 12:34:12 +0100
Subject: [PATCH 1/2] Remove Pivotal/VMWare/AsIs License and add ASF License Header
File: 0003-Remove-Pivotal-VMWare-AsIs-License-and-add-ASF-Licen.patch.txt


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

Branch: refs/heads/develop
Commit: b7b08d1c1903dd35fabe7595636896eafcf33de9
Parents: 2040242
Author: Dick Cavender <dc...@pivotal.io>
Authored: Thu Oct 22 15:39:20 2015 -0700
Committer: Dick Cavender <dc...@pivotal.io>
Committed: Thu Oct 22 15:39:20 2015 -0700

----------------------------------------------------------------------
 .../gemfire/OutOfOffHeapMemoryException.java    | 21 ++++++++++++-----
 .../cache/hdfs/internal/FlushObserver.java      | 16 +++++++++++++
 .../hdfs/internal/QueuedPersistentEvent.java    | 16 +++++++++++++
 .../hdfs/internal/SignalledFlushObserver.java   | 16 +++++++++++++
 .../cache/hdfs/internal/hoplog/FlushStatus.java | 16 +++++++++++++
 .../internal/hoplog/HDFSFlushQueueArgs.java     | 16 +++++++++++++
 .../internal/hoplog/HDFSFlushQueueFunction.java | 16 +++++++++++++
 .../gemfire/cache/lucene/LuceneQuery.java       | 16 +++++++++++++
 .../cache/lucene/LuceneQueryFactory.java        | 16 +++++++++++++
 .../cache/lucene/LuceneQueryResults.java        | 16 +++++++++++++
 .../cache/lucene/LuceneResultStruct.java        | 16 +++++++++++++
 .../gemfire/cache/lucene/LuceneService.java     | 16 +++++++++++++
 .../cache/lucene/LuceneServiceFactory.java      | 16 +++++++++++++
 .../cache/lucene/LuceneServiceProvider.java     | 16 +++++++++++++
 .../cache/lucene/internal/LuceneIndexImpl.java  | 16 +++++++++++++
 .../lucene/internal/LuceneQueryFactoryImpl.java | 16 +++++++++++++
 .../cache/lucene/internal/LuceneQueryImpl.java  | 16 +++++++++++++
 .../lucene/internal/LuceneQueryResultsImpl.java | 16 +++++++++++++
 .../lucene/internal/LuceneResultStructImpl.java | 16 +++++++++++++
 .../internal/LuceneServiceFactoryImpl.java      | 16 +++++++++++++
 .../lucene/internal/LuceneServiceImpl.java      | 16 +++++++++++++
 .../internal/GetOperationContextImpl.java       | 16 +++++++++++++
 .../gemfire/cache/query/Aggregator.java         | 16 +++++++++++++
 .../internal/CompiledAggregateFunction.java     | 16 +++++++++++++
 .../query/internal/CompiledGroupBySelect.java   | 16 +++++++++++++
 .../internal/CumulativeNonDistinctResults.java  | 16 +++++++++++++
 .../cache/query/internal/NWayMergeResults.java  | 16 +++++++++++++
 .../cache/query/internal/OrderByComparator.java | 18 ++++++++++++++-
 .../internal/OrderByComparatorUnmapped.java     | 16 +++++++++++++
 .../gemfire/cache/query/internal/Ordered.java   | 16 +++++++++++++
 .../cache/query/internal/PRQueryTraceInfo.java  | 22 ++++++++++++------
 .../cache/query/internal/SortedResultsBag.java  | 16 +++++++++++++
 .../cache/query/internal/SortedStructBag.java   | 16 +++++++++++++
 .../cache/query/internal/StructFields.java      | 16 +++++++++++++
 .../internal/aggregate/AbstractAggregator.java  | 16 +++++++++++++
 .../cache/query/internal/aggregate/Avg.java     | 16 +++++++++++++
 .../query/internal/aggregate/AvgBucketNode.java | 16 +++++++++++++
 .../query/internal/aggregate/AvgDistinct.java   | 16 +++++++++++++
 .../aggregate/AvgDistinctPRQueryNode.java       | 16 +++++++++++++
 .../internal/aggregate/AvgPRQueryNode.java      | 16 +++++++++++++
 .../cache/query/internal/aggregate/Count.java   | 16 +++++++++++++
 .../query/internal/aggregate/CountDistinct.java | 16 +++++++++++++
 .../aggregate/CountDistinctPRQueryNode.java     | 16 +++++++++++++
 .../internal/aggregate/CountPRQueryNode.java    | 16 +++++++++++++
 .../internal/aggregate/DistinctAggregator.java  | 16 +++++++++++++
 .../cache/query/internal/aggregate/MaxMin.java  | 16 +++++++++++++
 .../cache/query/internal/aggregate/Sum.java     | 16 +++++++++++++
 .../query/internal/aggregate/SumDistinct.java   | 16 +++++++++++++
 .../aggregate/SumDistinctPRQueryNode.java       | 16 +++++++++++++
 .../query/internal/parse/ASTAggregateFunc.java  | 16 +++++++++++++
 .../cache/query/internal/parse/ASTDummy.java    | 16 +++++++++++++
 .../query/internal/utils/LimitIterator.java     | 16 +++++++++++++
 .../cache/query/internal/utils/PDXUtils.java    | 16 +++++++++++++
 .../gemstone/gemfire/cache/util/Gateway.java    | 16 +++++++++++++
 .../gemfire/internal/ByteBufferWriter.java      | 16 +++++++++++++
 .../com/gemstone/gemfire/internal/Sendable.java | 18 ++++++++++++++-
 .../gemstone/gemfire/internal/SocketCloser.java | 16 +++++++++++++
 .../remote/ShutdownAllGatewayHubsRequest.java   | 16 +++++++++++++
 .../internal/cache/DistPeerTXStateStub.java     | 16 +++++++++++++
 .../cache/DistTXAdjunctCommitMessage.java       | 16 +++++++++++++
 .../internal/cache/DistTXCommitMessage.java     | 17 ++++++++++++--
 .../internal/cache/DistTXPrecommitMessage.java  | 17 ++++++++++++--
 .../internal/cache/DistTXRollbackMessage.java   | 17 ++++++++++++--
 .../gemfire/internal/cache/DistTXState.java     | 16 +++++++++++++
 .../cache/DistTXStateOnCoordinator.java         | 16 +++++++++++++
 .../internal/cache/DistTXStateProxyImpl.java    | 16 +++++++++++++
 .../DistTXStateProxyImplOnCoordinator.java      | 18 ++++++++++++++-
 .../cache/DistTXStateProxyImplOnDatanode.java   | 16 +++++++++++++
 .../gemfire/internal/cache/HDFSRegionMap.java   | 16 +++++++++++++
 .../internal/cache/OffHeapRegionEntry.java      | 16 +++++++++++++
 .../internal/cache/ServerPingMessage.java       | 16 +++++++++++++
 .../cache/VMThinRegionEntryOffHeap.java         | 16 +++++++++++++
 .../cache/control/HeapMemoryMonitor.java        | 21 ++++++++++++-----
 .../cache/control/MemoryThresholds.java         | 16 +++++++++++++
 .../cache/control/OffHeapMemoryMonitor.java     | 21 ++++++++++++-----
 .../internal/cache/control/ResourceMonitor.java | 16 +++++++++++++
 .../internal/cache/lru/OffHeapEvictor.java      | 21 ++++++++++++-----
 .../DestroyRegionOnDataStoreMessage.java        | 20 +++++++++++-----
 .../rebalance/ParallelBucketOperator.java       | 16 +++++++++++++
 .../cache/tx/DistClientTXStateStub.java         | 19 +++++++++++++---
 .../internal/cache/tx/DistTxEntryEvent.java     | 16 +++++++++++++
 .../internal/cache/tx/DistTxKeyInfo.java        | 18 ++++++++++++++-
 .../cache/xmlcache/CacheXmlVersion.java         | 17 ++++++++++++--
 .../internal/logging/log4j/ConfigLocator.java   | 16 +++++++++++++
 .../internal/offheap/ByteArrayMemoryChunk.java  | 16 +++++++++++++
 .../internal/offheap/ByteBufferMemoryChunk.java | 16 +++++++++++++
 .../gemfire/internal/offheap/DataType.java      | 16 +++++++++++++
 .../internal/offheap/MemoryAllocator.java       | 16 +++++++++++++
 .../gemfire/internal/offheap/MemoryBlock.java   | 16 +++++++++++++
 .../gemfire/internal/offheap/MemoryChunk.java   | 16 +++++++++++++
 .../offheap/MemoryChunkWithRefCount.java        | 16 +++++++++++++
 .../internal/offheap/MemoryInspector.java       | 16 +++++++++++++
 .../internal/offheap/MemoryUsageListener.java   | 16 +++++++++++++
 .../offheap/OffHeapCachedDeserializable.java    | 16 +++++++++++++
 .../gemfire/internal/offheap/OffHeapHelper.java | 16 +++++++++++++
 .../internal/offheap/OffHeapMemoryStats.java    | 16 +++++++++++++
 .../internal/offheap/OffHeapReference.java      | 18 ++++++++++++++-
 .../offheap/OffHeapRegionEntryHelper.java       | 16 +++++++++++++
 .../internal/offheap/OffHeapStorage.java        | 16 +++++++++++++
 .../offheap/OutOfOffHeapMemoryListener.java     | 16 +++++++++++++
 .../gemfire/internal/offheap/Releasable.java    | 16 +++++++++++++
 .../offheap/SimpleMemoryAllocatorImpl.java      | 16 +++++++++++++
 .../gemfire/internal/offheap/StoredObject.java  | 16 +++++++++++++
 .../internal/offheap/UnsafeMemoryChunk.java     | 16 +++++++++++++
 .../offheap/annotations/OffHeapIdentifier.java  | 16 +++++++++++++
 .../internal/offheap/annotations/Released.java  | 16 +++++++++++++
 .../internal/offheap/annotations/Retained.java  | 16 +++++++++++++
 .../offheap/annotations/Unretained.java         | 16 +++++++++++++
 .../process/BlockingProcessStreamReader.java    | 16 +++++++++++++
 .../process/NonBlockingProcessStreamReader.java | 16 +++++++++++++
 .../gemfire/internal/process/PidFile.java       | 16 +++++++++++++
 .../internal/redis/ByteArrayWrapper.java        | 16 +++++++++++++
 .../internal/redis/ByteToCommandDecoder.java    | 16 +++++++++++++
 .../gemstone/gemfire/internal/redis/Coder.java  | 16 +++++++++++++
 .../gemfire/internal/redis/Command.java         | 16 +++++++++++++
 .../gemfire/internal/redis/DoubleWrapper.java   | 16 +++++++++++++
 .../internal/redis/ExecutionHandlerContext.java | 16 +++++++++++++
 .../gemfire/internal/redis/Executor.java        | 16 +++++++++++++
 .../gemfire/internal/redis/Extendable.java      | 16 +++++++++++++
 .../redis/RedisCommandParserException.java      | 16 +++++++++++++
 .../internal/redis/RedisCommandType.java        | 16 +++++++++++++
 .../gemfire/internal/redis/RedisConstants.java  | 16 +++++++++++++
 .../gemfire/internal/redis/RedisDataType.java   | 18 ++++++++++++++-
 .../redis/RedisDataTypeMismatchException.java   | 16 +++++++++++++
 .../internal/redis/RegionCreationException.java | 16 +++++++++++++
 .../gemfire/internal/redis/RegionProvider.java  | 16 +++++++++++++
 .../redis/executor/AbstractExecutor.java        | 16 +++++++++++++
 .../redis/executor/AbstractScanExecutor.java    | 16 +++++++++++++
 .../internal/redis/executor/AuthExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/DBSizeExecutor.java | 16 +++++++++++++
 .../internal/redis/executor/DelExecutor.java    | 16 +++++++++++++
 .../internal/redis/executor/EchoExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/ExistsExecutor.java | 16 +++++++++++++
 .../redis/executor/ExpirationExecutor.java      | 16 +++++++++++++
 .../redis/executor/ExpireAtExecutor.java        | 16 +++++++++++++
 .../internal/redis/executor/ExpireExecutor.java | 16 +++++++++++++
 .../redis/executor/FlushAllExecutor.java        | 16 +++++++++++++
 .../internal/redis/executor/KeysExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/ListQuery.java      | 16 +++++++++++++
 .../redis/executor/PExpireAtExecutor.java       | 16 +++++++++++++
 .../redis/executor/PExpireExecutor.java         | 16 +++++++++++++
 .../internal/redis/executor/PTTLExecutor.java   | 16 +++++++++++++
 .../redis/executor/PersistExecutor.java         | 16 +++++++++++++
 .../internal/redis/executor/PingExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/QuitExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/ScanExecutor.java   | 16 +++++++++++++
 .../redis/executor/ShutDownExecutor.java        | 16 +++++++++++++
 .../internal/redis/executor/SortedSetQuery.java | 16 +++++++++++++
 .../internal/redis/executor/TTLExecutor.java    | 16 +++++++++++++
 .../internal/redis/executor/TimeExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/TypeExecutor.java   | 16 +++++++++++++
 .../internal/redis/executor/UnkownExecutor.java | 16 +++++++++++++
 .../redis/executor/hash/HDelExecutor.java       | 16 +++++++++++++
 .../redis/executor/hash/HExistsExecutor.java    | 16 +++++++++++++
 .../redis/executor/hash/HGetAllExecutor.java    | 16 +++++++++++++
 .../redis/executor/hash/HGetExecutor.java       | 16 +++++++++++++
 .../redis/executor/hash/HIncrByExecutor.java    | 16 +++++++++++++
 .../executor/hash/HIncrByFloatExecutor.java     | 16 +++++++++++++
 .../redis/executor/hash/HKeysExecutor.java      | 16 +++++++++++++
 .../redis/executor/hash/HLenExecutor.java       | 16 +++++++++++++
 .../redis/executor/hash/HMGetExecutor.java      | 16 +++++++++++++
 .../redis/executor/hash/HMSetExecutor.java      | 16 +++++++++++++
 .../redis/executor/hash/HScanExecutor.java      | 16 +++++++++++++
 .../redis/executor/hash/HSetExecutor.java       | 16 +++++++++++++
 .../redis/executor/hash/HSetNXExecutor.java     | 16 +++++++++++++
 .../redis/executor/hash/HValsExecutor.java      | 16 +++++++++++++
 .../redis/executor/hash/HashExecutor.java       | 18 ++++++++++++++-
 .../internal/redis/executor/hll/Bits.java       | 16 +++++++++++++
 .../executor/hll/CardinalityMergeException.java | 18 ++++++++++++++-
 .../redis/executor/hll/HllExecutor.java         | 16 +++++++++++++
 .../redis/executor/hll/HyperLogLog.java         | 16 +++++++++++++
 .../redis/executor/hll/HyperLogLogPlus.java     | 18 ++++++++++++++-
 .../internal/redis/executor/hll/IBuilder.java   | 18 ++++++++++++++-
 .../redis/executor/hll/ICardinality.java        | 16 +++++++++++++
 .../internal/redis/executor/hll/MurmurHash.java | 18 ++++++++++++++-
 .../redis/executor/hll/PFAddExecutor.java       | 16 +++++++++++++
 .../redis/executor/hll/PFCountExecutor.java     | 16 +++++++++++++
 .../redis/executor/hll/PFMergeExecutor.java     | 16 +++++++++++++
 .../redis/executor/hll/RegisterSet.java         | 18 ++++++++++++++-
 .../internal/redis/executor/hll/Varint.java     | 18 ++++++++++++++-
 .../redis/executor/list/LIndexExecutor.java     | 16 +++++++++++++
 .../redis/executor/list/LInsertExecutor.java    | 16 +++++++++++++
 .../redis/executor/list/LLenExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/LPopExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/LPushExecutor.java      | 16 +++++++++++++
 .../redis/executor/list/LPushXExecutor.java     | 16 +++++++++++++
 .../redis/executor/list/LRangeExecutor.java     | 16 +++++++++++++
 .../redis/executor/list/LRemExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/LSetExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/LTrimExecutor.java      | 16 +++++++++++++
 .../redis/executor/list/ListExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/PopExecutor.java        | 16 +++++++++++++
 .../redis/executor/list/PushExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/PushXExecutor.java      | 16 +++++++++++++
 .../redis/executor/list/RPopExecutor.java       | 16 +++++++++++++
 .../redis/executor/list/RPushExecutor.java      | 16 +++++++++++++
 .../redis/executor/list/RPushXExecutor.java     | 16 +++++++++++++
 .../redis/executor/set/SAddExecutor.java        | 16 +++++++++++++
 .../redis/executor/set/SCardExecutor.java       | 16 +++++++++++++
 .../redis/executor/set/SDiffExecutor.java       | 16 +++++++++++++
 .../redis/executor/set/SDiffStoreExecutor.java  | 16 +++++++++++++
 .../redis/executor/set/SInterExecutor.java      | 16 +++++++++++++
 .../redis/executor/set/SInterStoreExecutor.java | 16 +++++++++++++
 .../redis/executor/set/SIsMemberExecutor.java   | 16 +++++++++++++
 .../redis/executor/set/SMembersExecutor.java    | 16 +++++++++++++
 .../redis/executor/set/SMoveExecutor.java       | 16 +++++++++++++
 .../redis/executor/set/SPopExecutor.java        | 16 +++++++++++++
 .../redis/executor/set/SRandMemberExecutor.java | 16 +++++++++++++
 .../redis/executor/set/SRemExecutor.java        | 16 +++++++++++++
 .../redis/executor/set/SScanExecutor.java       | 16 +++++++++++++
 .../redis/executor/set/SUnionExecutor.java      | 16 +++++++++++++
 .../redis/executor/set/SUnionStoreExecutor.java | 16 +++++++++++++
 .../redis/executor/set/SetExecutor.java         | 16 +++++++++++++
 .../redis/executor/set/SetOpExecutor.java       | 16 +++++++++++++
 .../executor/sortedset/SortedSetExecutor.java   | 16 +++++++++++++
 .../redis/executor/sortedset/ZAddExecutor.java  | 16 +++++++++++++
 .../redis/executor/sortedset/ZCardExecutor.java | 16 +++++++++++++
 .../executor/sortedset/ZCountExecutor.java      | 16 +++++++++++++
 .../executor/sortedset/ZIncrByExecutor.java     | 16 +++++++++++++
 .../executor/sortedset/ZLexCountExecutor.java   | 16 +++++++++++++
 .../executor/sortedset/ZRangeByLexExecutor.java | 16 +++++++++++++
 .../sortedset/ZRangeByScoreExecutor.java        | 16 +++++++++++++
 .../executor/sortedset/ZRangeExecutor.java      | 16 +++++++++++++
 .../redis/executor/sortedset/ZRankExecutor.java | 16 +++++++++++++
 .../redis/executor/sortedset/ZRemExecutor.java  | 16 +++++++++++++
 .../sortedset/ZRemRangeByLexExecutor.java       | 16 +++++++++++++
 .../sortedset/ZRemRangeByRankExecutor.java      | 16 +++++++++++++
 .../sortedset/ZRemRangeByScoreExecutor.java     | 16 +++++++++++++
 .../sortedset/ZRevRangeByScoreExecutor.java     | 16 +++++++++++++
 .../executor/sortedset/ZRevRangeExecutor.java   | 16 +++++++++++++
 .../executor/sortedset/ZRevRankExecutor.java    | 16 +++++++++++++
 .../redis/executor/sortedset/ZScanExecutor.java | 16 +++++++++++++
 .../executor/sortedset/ZScoreExecutor.java      | 16 +++++++++++++
 .../redis/executor/string/AppendExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/BitCountExecutor.java | 16 +++++++++++++
 .../redis/executor/string/BitOpExecutor.java    | 16 +++++++++++++
 .../redis/executor/string/BitPosExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/DecrByExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/DecrExecutor.java     | 16 +++++++++++++
 .../redis/executor/string/GetBitExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/GetExecutor.java      | 16 +++++++++++++
 .../redis/executor/string/GetRangeExecutor.java | 16 +++++++++++++
 .../redis/executor/string/GetSetExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/IncrByExecutor.java   | 16 +++++++++++++
 .../executor/string/IncrByFloatExecutor.java    | 16 +++++++++++++
 .../redis/executor/string/IncrExecutor.java     | 16 +++++++++++++
 .../redis/executor/string/MGetExecutor.java     | 16 +++++++++++++
 .../redis/executor/string/MSetExecutor.java     | 16 +++++++++++++
 .../redis/executor/string/MSetNXExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/PSetEXExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/SetBitExecutor.java   | 16 +++++++++++++
 .../redis/executor/string/SetEXExecutor.java    | 16 +++++++++++++
 .../redis/executor/string/SetExecutor.java      | 16 +++++++++++++
 .../redis/executor/string/SetNXExecutor.java    | 16 +++++++++++++
 .../redis/executor/string/SetRangeExecutor.java | 16 +++++++++++++
 .../redis/executor/string/StringExecutor.java   | 18 ++++++++++++++-
 .../redis/executor/string/StrlenExecutor.java   | 16 +++++++++++++
 .../executor/transactions/DiscardExecutor.java  | 16 +++++++++++++
 .../executor/transactions/ExecExecutor.java     | 16 +++++++++++++
 .../executor/transactions/MultiExecutor.java    | 16 +++++++++++++
 .../transactions/TransactionExecutor.java       | 16 +++++++++++++
 .../executor/transactions/UnwatchExecutor.java  | 16 +++++++++++++
 .../executor/transactions/WatchExecutor.java    | 16 +++++++++++++
 .../internal/util/SingletonCallable.java        | 16 +++++++++++++
 .../gemfire/internal/util/SingletonValue.java   | 18 ++++++++++++++-
 .../internal/util/StackTraceCollector.java      | 21 ++++++++++++-----
 .../cli/commands/HDFSStoreCommands.java         | 16 +++++++++++++
 .../cli/functions/CreateHDFSStoreFunction.java  | 16 +++++++++++++
 .../functions/DescribeHDFSStoreFunction.java    | 16 +++++++++++++
 .../pdx/PdxRegistryMismatchException.java       | 24 ++++++++++++--------
 .../gemfire/redis/GemFireRedisServer.java       | 18 ++++++++++++++-
 .../src/test/java/cacheRunner/Portfolio.java    | 16 +++++++++++++
 .../src/test/java/cacheRunner/Position.java     | 16 +++++++++++++
 .../java/com/company/data/MyDeclarable.java     | 16 +++++++++++++
 .../src/test/java/com/examples/ds/Address.java  | 16 +++++++++++++
 .../java/com/gemstone/gemfire/AppObject.java    | 18 ++++++++++++++-
 .../com/gemstone/gemfire/TXWriterTestCase.java  | 16 +++++++++++++
 .../cache/ClientServerTimeSyncDUnitTest.java    | 16 +++++++++++++
 .../ClientServerRegisterInterestsDUnitTest.java | 16 +++++++++++++
 .../internal/SSLNoClientAuthDUnitTest.java      | 21 ++++++++++++-----
 .../SignalledFlushObserverJUnitTest.java        | 16 +++++++++++++
 .../MemoryThresholdsOffHeapDUnitTest.java       | 21 ++++++++++++-----
 .../PutOperationContextJUnitTest.java           | 16 +++++++++++++
 .../GetOperationContextImplJUnitTest.java       | 16 +++++++++++++
 .../dunit/GroupByPartitionedQueryDUnitTest.java | 16 +++++++++++++
 .../functional/GroupByPartitionedJUnitTest.java | 16 +++++++++++++
 .../functional/GroupByReplicatedJUnitTest.java  | 16 +++++++++++++
 .../query/functional/GroupByTestInterface.java  | 16 +++++++++++++
 .../functional/MultiIndexCreationJUnitTest.java | 16 +++++++++++++
 .../NonDistinctOrderByPartitionedJUnitTest.java | 16 +++++++++++++
 .../NonDistinctOrderByReplicatedJUnitTest.java  | 16 +++++++++++++
 .../functional/OrderByPartitionedJUnitTest.java | 16 +++++++++++++
 .../functional/OrderByReplicatedJUnitTest.java  | 16 +++++++++++++
 .../PdxGroupByPartitionedJUnitTest.java         | 16 +++++++++++++
 .../PdxGroupByReplicatedJUnitTest.java          | 16 +++++++++++++
 .../query/functional/PdxGroupByTestImpl.java    | 16 +++++++++++++
 .../query/functional/PdxOrderByJUnitTest.java   | 16 +++++++++++++
 .../CompiledAggregateFunctionJUnitTest.java     | 16 +++++++++++++
 .../CompiledGroupBySelectJUnitTest.java         | 16 +++++++++++++
 .../internal/NWayMergeResultsJUnitTest.java     | 16 +++++++++++++
 .../internal/aggregate/AggregatorJUnitTest.java | 16 +++++++++++++
 .../internal/index/IndexHintJUnitTest.java      | 16 +++++++++++++
 .../index/MultiIndexCreationDUnitTest.java      | 16 +++++++++++++
 .../index/PdxCopyOnReadQueryJUnitTest.java      | 16 +++++++++++++
 .../gemfire/cache30/CacheXmlTestCase.java       | 16 +++++++++++++
 .../ClientMembershipSelectorDUnitTest.java      | 16 +++++++++++++
 ...ClientRegisterInterestSelectorDUnitTest.java | 16 +++++++++++++
 ...dAckPersistentRegionCCEOffHeapDUnitTest.java | 16 +++++++++++++
 ...DistributedAckRegionCCEOffHeapDUnitTest.java | 16 +++++++++++++
 .../DistributedAckRegionOffHeapDUnitTest.java   | 16 +++++++++++++
 ...stributedNoAckRegionCCEOffHeapDUnitTest.java | 16 +++++++++++++
 .../DistributedNoAckRegionOffHeapDUnitTest.java | 16 +++++++++++++
 .../GlobalRegionCCEOffHeapDUnitTest.java        | 16 +++++++++++++
 .../cache30/GlobalRegionOffHeapDUnitTest.java   | 16 +++++++++++++
 .../OffHeapLRUEvictionControllerDUnitTest.java  | 21 ++++++++++++-----
 .../PartitionedRegionOffHeapDUnitTest.java      | 16 +++++++++++++
 .../codeAnalysis/decode/cp/CpFieldref.java      | 18 ++++++++++++++-
 .../gemfire/codeAnalysis/decode/cp/CpFloat.java | 18 ++++++++++++++-
 .../codeAnalysis/decode/cp/CpInteger.java       | 18 ++++++++++++++-
 .../decode/cp/CpInterfaceMethodref.java         | 18 ++++++++++++++-
 .../codeAnalysis/decode/cp/CpMethodref.java     | 18 ++++++++++++++-
 .../codeAnalysis/decode/cp/CpNameAndType.java   | 18 ++++++++++++++-
 .../codeAnalysis/decode/cp/CpString.java        | 18 ++++++++++++++-
 .../AbstractLauncherJUnitTestCase.java          | 16 +++++++++++++
 .../AbstractLocatorLauncherJUnitTestCase.java   | 16 +++++++++++++
 .../AbstractServerLauncherJUnitTestCase.java    | 16 +++++++++++++
 .../distributed/DistributedTestSuite.java       | 16 +++++++++++++
 .../distributed/HostedLocatorsDUnitTest.java    | 16 +++++++++++++
 .../LauncherMemberMXBeanJUnitTest.java          | 16 +++++++++++++
 .../gemfire/distributed/LauncherTestSuite.java  | 16 +++++++++++++
 .../LocatorLauncherLocalFileJUnitTest.java      | 16 +++++++++++++
 .../LocatorLauncherLocalJUnitTest.java          | 16 +++++++++++++
 .../LocatorLauncherRemoteFileJUnitTest.java     | 16 +++++++++++++
 .../LocatorLauncherRemoteJUnitTest.java         | 16 +++++++++++++
 .../gemfire/distributed/MyPrincipal.java        | 18 ++++++++++++++-
 .../ServerLauncherWithSpringJUnitTest.java      | 16 +++++++++++++
 .../tcpserver/LocatorVersioningJUnitTest.java   | 17 ++++++++++++--
 ...cpServerBackwardCompatDUnitDisabledTest.java | 17 ++++++++++++--
 .../tcpserver/TcpServerJUnitDisabledTest.java   | 16 +++++++++++++
 .../gemfire/disttx/CacheMapDistTXDUnitTest.java | 16 +++++++++++++
 .../gemfire/disttx/DistTXDebugDUnitTest.java    | 16 +++++++++++++
 .../disttx/DistTXDistributedTestSuite.java      | 16 +++++++++++++
 .../gemfire/disttx/DistTXExpiryJUnitTest.java   | 16 +++++++++++++
 .../gemfire/disttx/DistTXJUnitTest.java         | 16 +++++++++++++
 .../disttx/DistTXManagerImplJUnitTest.java      | 16 +++++++++++++
 .../gemfire/disttx/DistTXOrderDUnitTest.java    | 16 +++++++++++++
 .../disttx/DistTXPersistentDebugDUnitTest.java  | 18 ++++++++++++++-
 .../DistTXReleasesOffHeapOnCloseJUnitTest.java  | 16 +++++++++++++
 .../disttx/DistTXRestrictionsDUnitTest.java     | 16 +++++++++++++
 .../disttx/DistTXWithDeltaDUnitTest.java        | 16 +++++++++++++
 .../gemfire/disttx/DistTXWriterJUnitTest.java   | 16 +++++++++++++
 .../disttx/DistTXWriterOOMEJUnitTest.java       | 16 +++++++++++++
 .../disttx/DistributedTransactionDUnitTest.java | 18 ++++++++++++++-
 .../gemfire/disttx/PRDistTXDUnitTest.java       | 16 +++++++++++++
 .../gemfire/disttx/PRDistTXJUnitTest.java       | 16 +++++++++++++
 .../disttx/PRDistTXWithVersionsDUnitTest.java   | 16 +++++++++++++
 ...entPartitionedRegionWithDistTXDUnitTest.java | 16 +++++++++++++
 .../gemfire/internal/Bug51616JUnitTest.java     | 16 +++++++++++++
 .../gemstone/gemfire/internal/FDDUnitTest.java  | 17 ++++++++++----
 .../internal/PdxDeleteFieldDUnitTest.java       | 16 +++++++++++++
 .../internal/PdxDeleteFieldJUnitTest.java       | 16 +++++++++++++
 .../gemfire/internal/PdxRenameDUnitTest.java    | 16 +++++++++++++
 .../gemfire/internal/PdxRenameJUnitTest.java    | 16 +++++++++++++
 .../gemfire/internal/SocketCloserJUnitTest.java | 16 +++++++++++++
 .../internal/SocketCloserWithWaitJUnitTest.java | 16 +++++++++++++
 .../internal/cache/Bug48182JUnitTest.java       | 16 +++++++++++++
 .../cache/ChunkValueWrapperJUnitTest.java       | 16 +++++++++++++
 .../cache/ConnectDisconnectDUnitTest.java       | 16 +++++++++++++
 ...DistrbutedRegionProfileOffHeapDUnitTest.java | 16 +++++++++++++
 ...InterruptsConserveSocketsFalseDUnitTest.java | 16 +++++++++++++
 .../cache/OffHeapEvictionDUnitTest.java         | 21 ++++++++++++-----
 .../cache/OffHeapEvictionStatsDUnitTest.java    | 21 ++++++++++++-----
 .../cache/OldValueImporterTestBase.java         | 16 +++++++++++++
 .../PRDataStoreMemoryOffHeapJUnitTest.java      | 16 +++++++++++++
 .../cache/PartitionAttributesImplJUnitTest.java | 16 +++++++++++++
 ...nedRegionLocalMaxMemoryOffHeapDUnitTest.java | 16 +++++++++++++
 ...rtitionedRegionOffHeapEvictionDUnitTest.java | 18 ++++++++++++++-
 .../PersistentPartitionedRegionJUnitTest.java   | 16 +++++++++++++
 .../cache/RemotePutReplyMessageJUnitTest.java   | 16 +++++++++++++
 .../cache/RemoteTransactionCCEDUnitTest.java    | 16 +++++++++++++
 .../internal/cache/SnapshotTestUtil.java        | 16 +++++++++++++
 .../internal/cache/TestHelperForHydraTests.java | 16 +++++++++++++
 .../internal/cache/UnitTestValueHolder.java     | 18 ++++++++++++++-
 .../control/MemoryMonitorOffHeapJUnitTest.java  | 21 ++++++++++++-----
 .../control/MemoryThresholdsJUnitTest.java      | 16 +++++++++++++
 .../cache/execute/Bug51193DUnitTest.java        | 16 +++++++++++++
 .../PRTransactionWithVersionsDUnitTest.java     | 16 +++++++++++++
 .../internal/cache/ha/Bug48879DUnitTest.java    | 16 +++++++++++++
 .../PutPutReplyMessageJUnitTest.java            | 16 +++++++++++++
 .../SizeTieredSortedOplogSetJUnitTest.java      | 16 +++++++++++++
 .../soplog/SortedBufferJUnitTest.java           | 16 +++++++++++++
 ...heServerSelectorMaxConnectionsJUnitTest.java | 16 +++++++++++++
 ...acheServerTransactionsSelectorDUnitTest.java | 16 +++++++++++++
 .../ClientHealthMonitorSelectorJUnitTest.java   | 16 +++++++++++++
 .../DurableClientQueueSizeDUnitTest.java        | 17 ++++++++++++--
 ...ForceInvalidateOffHeapEvictionDUnitTest.java | 21 ++++++++++++-----
 .../sockets/HAInterestDistributedTestCase.java  | 16 +++++++++++++
 .../internal/cache/tier/sockets/HaHelper.java   | 16 +++++++++++++
 .../InterestListEndpointSelectorDUnitTest.java  | 16 +++++++++++++
 ...ompressionCacheListenerOffHeapDUnitTest.java | 16 +++++++++++++
 ...ressionRegionOperationsOffHeapDUnitTest.java | 16 +++++++++++++
 .../internal/jta/JtaIntegrationJUnitTest.java   | 16 +++++++++++++
 .../DistributedSystemLogFileJUnitTest.java      | 16 +++++++++++++
 .../logging/LocatorLogFileJUnitTest.java        | 16 +++++++++++++
 .../logging/LogServiceIntegrationJUnitTest.java | 16 +++++++++++++
 .../LogServiceIntegrationTestSupport.java       | 16 +++++++++++++
 .../internal/logging/LogServiceJUnitTest.java   | 16 +++++++++++++
 .../LogWriterDisabledPerformanceTest.java       | 16 +++++++++++++
 .../logging/LogWriterImplJUnitTest.java         | 16 +++++++++++++
 .../logging/LogWriterPerformanceTest.java       | 16 +++++++++++++
 .../logging/LoggingIntegrationTestSuite.java    | 16 +++++++++++++
 .../logging/LoggingPerformanceTestCase.java     | 16 +++++++++++++
 .../internal/logging/LoggingUnitTestSuite.java  | 16 +++++++++++++
 .../gemfire/internal/logging/NullLogWriter.java | 16 +++++++++++++
 .../internal/logging/TestLogWriterFactory.java  | 16 +++++++++++++
 .../logging/log4j/AlertAppenderJUnitTest.java   | 16 +++++++++++++
 .../logging/log4j/ConfigLocatorJUnitTest.java   | 16 +++++++++++++
 .../log4j/FastLoggerIntegrationJUnitTest.java   | 16 +++++++++++++
 .../logging/log4j/FastLoggerJUnitTest.java      | 16 +++++++++++++
 .../FastLoggerWithDefaultConfigJUnitTest.java   | 16 +++++++++++++
 .../log4j/LocalizedMessageJUnitTest.java        | 16 +++++++++++++
 .../log4j/Log4J2DisabledPerformanceTest.java    | 16 +++++++++++++
 .../logging/log4j/Log4J2PerformanceTest.java    | 16 +++++++++++++
 .../log4j/Log4jIntegrationTestSuite.java        | 16 +++++++++++++
 .../logging/log4j/Log4jUnitTestSuite.java       | 16 +++++++++++++
 .../log4j/LogWriterAppenderJUnitTest.java       | 16 +++++++++++++
 .../LogWriterLoggerDisabledPerformanceTest.java | 16 +++++++++++++
 .../log4j/LogWriterLoggerPerformanceTest.java   | 16 +++++++++++++
 .../offheap/ByteArrayMemoryChunkJUnitTest.java  | 16 +++++++++++++
 .../offheap/ConcurrentBagJUnitTest.java         | 16 +++++++++++++
 .../internal/offheap/DataTypeJUnitTest.java     | 16 +++++++++++++
 .../DirectByteBufferMemoryChunkJUnitTest.java   | 16 +++++++++++++
 .../offheap/FreeListOffHeapRegionJUnitTest.java | 16 +++++++++++++
 .../HeapByteBufferMemoryChunkJUnitTest.java     | 16 +++++++++++++
 .../internal/offheap/InlineKeyJUnitTest.java    | 16 +++++++++++++
 .../offheap/MemoryChunkJUnitTestBase.java       | 16 +++++++++++++
 .../offheap/NullOffHeapMemoryStats.java         | 16 +++++++++++++
 .../offheap/NullOutOfOffHeapMemoryListener.java | 16 +++++++++++++
 .../internal/offheap/OffHeapIndexJUnitTest.java | 16 +++++++++++++
 .../internal/offheap/OffHeapRegionBase.java     | 16 +++++++++++++
 .../offheap/OffHeapStorageJUnitTest.java        | 16 +++++++++++++
 .../offheap/OffHeapValidationJUnitTest.java     | 16 +++++++++++++
 .../OffHeapWriteObjectAsByteArrayJUnitTest.java | 16 +++++++++++++
 .../OldFreeListOffHeapRegionJUnitTest.java      | 16 +++++++++++++
 .../offheap/OutOfOffHeapMemoryDUnitTest.java    | 16 +++++++++++++
 ...mpleMemoryAllocatorFillPatternJUnitTest.java | 16 +++++++++++++
 .../offheap/SimpleMemoryAllocatorJUnitTest.java | 16 +++++++++++++
 ...moryAllocatorLifecycleListenerJUnitTest.java | 16 +++++++++++++
 .../TxReleasesOffHeapOnCloseJUnitTest.java      | 16 +++++++++++++
 .../offheap/UnsafeMemoryChunkJUnitTest.java     | 16 +++++++++++++
 .../BlockingProcessStreamReaderJUnitTest.java   | 16 +++++++++++++
 ...NonBlockingProcessStreamReaderJUnitTest.java | 16 +++++++++++++
 .../internal/process/PidFileJUnitTest.java      | 16 +++++++++++++
 .../ProcessControllerFactoryJUnitTest.java      | 16 +++++++++++++
 .../process/ProcessStreamReaderTestCase.java    | 16 +++++++++++++
 .../gemfire/internal/process/mbean/Process.java | 16 +++++++++++++
 .../internal/process/mbean/ProcessMBean.java    | 16 +++++++++++++
 .../gemfire/internal/size/SizeTestUtil.java     | 16 +++++++++++++
 .../gemfire/management/CompositeTestMXBean.java | 16 +++++++++++++
 .../management/OffHeapManagementDUnitTest.java  | 16 +++++++++++++
 .../cli/CommandSeparatorEscapeJUnitTest.java    | 16 +++++++++++++
 .../internal/cli/DataCommandJsonJUnitTest.java  | 16 +++++++++++++
 .../internal/cli/domain/AbstractImpl.java       | 16 +++++++++++++
 .../management/internal/cli/domain/Impl1.java   | 16 +++++++++++++
 .../management/internal/cli/domain/Impl12.java  | 16 +++++++++++++
 .../internal/cli/domain/Interface1.java         | 16 +++++++++++++
 .../internal/cli/domain/Interface2.java         | 16 +++++++++++++
 .../management/internal/cli/dto/Car.java        | 16 +++++++++++++
 .../WanCommandsControllerJUnitTest.java         | 16 +++++++++++++
 .../gemfire/pdx/ByteSourceJUnitTest.java        | 16 +++++++++++++
 .../gemstone/gemfire/pdx/DomainObjectBad.java   | 16 +++++++++++++
 .../gemfire/pdx/DomainObjectClassLoadable.java  | 16 +++++++++++++
 .../OffHeapByteBufferByteSourceJUnitTest.java   | 16 +++++++++++++
 .../gemfire/pdx/OffHeapByteSourceJUnitTest.java | 16 +++++++++++++
 .../gemstone/gemfire/redis/AuthJUnitTest.java   | 18 ++++++++++++++-
 .../gemfire/redis/ConcurrentStartTest.java      | 16 +++++++++++++
 .../gemstone/gemfire/redis/HashesJUnitTest.java | 16 +++++++++++++
 .../gemstone/gemfire/redis/ListsJUnitTest.java  | 16 +++++++++++++
 .../gemfire/redis/RedisDistDUnitTest.java       | 16 +++++++++++++
 .../gemstone/gemfire/redis/SetsJUnitTest.java   | 16 +++++++++++++
 .../gemfire/redis/SortedSetsJUnitTest.java      | 16 +++++++++++++
 .../gemfire/redis/StringsJunitTest.java         | 16 +++++++++++++
 .../internal/web/controllers/DateTimeUtils.java | 16 +++++++++++++
 .../rest/internal/web/controllers/Gender.java   | 16 +++++++++++++
 .../web/controllers/RestAPITestBase.java        | 16 +++++++++++++
 .../gemfire/test/golden/ExecutableProcess.java  | 16 +++++++++++++
 .../gemfire/test/golden/FailOutputTestCase.java | 16 +++++++++++++
 .../golden/FailWithErrorInOutputJUnitTest.java  | 16 +++++++++++++
 .../FailWithExtraLineInOutputJUnitTest.java     | 16 +++++++++++++
 ...WithLineMissingFromEndOfOutputJUnitTest.java | 16 +++++++++++++
 ...hLineMissingFromMiddleOfOutputJUnitTest.java | 16 +++++++++++++
 .../FailWithLoggerErrorInOutputJUnitTest.java   | 16 +++++++++++++
 .../FailWithLoggerFatalInOutputJUnitTest.java   | 16 +++++++++++++
 .../FailWithLoggerWarnInOutputJUnitTest.java    | 16 +++++++++++++
 .../golden/FailWithProblemInOutputTestCase.java | 16 +++++++++++++
 .../golden/FailWithSevereInOutputJUnitTest.java | 16 +++++++++++++
 ...hTimeoutOfWaitForOutputToMatchJUnitTest.java | 16 +++++++++++++
 .../FailWithWarningInOutputJUnitTest.java       | 16 +++++++++++++
 .../gemfire/test/golden/GoldenComparator.java   | 16 +++++++++++++
 .../test/golden/GoldenStringComparator.java     | 16 +++++++++++++
 .../gemfire/test/golden/GoldenTestCase.java     | 16 +++++++++++++
 .../golden/GoldenTestFrameworkTestSuite.java    | 16 +++++++++++++
 .../gemfire/test/golden/PassJUnitTest.java      | 16 +++++++++++++
 .../golden/PassWithExpectedErrorJUnitTest.java  | 16 +++++++++++++
 .../golden/PassWithExpectedProblemTestCase.java | 16 +++++++++++++
 .../golden/PassWithExpectedSevereJUnitTest.java | 16 +++++++++++++
 .../PassWithExpectedWarningJUnitTest.java       | 16 +++++++++++++
 .../test/golden/RegexGoldenComparator.java      | 16 +++++++++++++
 .../test/golden/StringGoldenComparator.java     | 16 +++++++++++++
 .../gemfire/test/process/MainLauncher.java      | 16 +++++++++++++
 .../test/process/MainLauncherJUnitTest.java     | 16 +++++++++++++
 .../gemfire/test/process/OutputFormatter.java   | 16 +++++++++++++
 .../test/process/ProcessOutputReader.java       | 16 +++++++++++++
 .../test/process/ProcessStreamReader.java       | 16 +++++++++++++
 .../process/ProcessTestFrameworkTestSuite.java  | 16 +++++++++++++
 .../gemfire/test/process/ProcessWrapper.java    | 16 +++++++++++++
 .../test/process/ProcessWrapperJUnitTest.java   | 16 +++++++++++++
 .../protocols/CacheTimeSlowDownDUnitTest.java   | 17 ++++++++++++--
 .../GemFireTimeSyncProtocolDUnitTest.java       | 17 ++++++++++++--
 .../JGroupsFailureDetectionJUnitTest.java       | 16 +++++++++++++
 .../src/test/java/dunit/BounceResult.java       | 16 +++++++++++++
 .../src/test/java/dunit/RemoteDUnitVMIF.java    | 16 +++++++++++++
 .../src/test/java/dunit/RepeatableRunnable.java | 16 +++++++++++++
 .../templates/security/DummyAuthenticator.java  | 21 +++++++++++++----
 .../templates/security/DummyAuthorization.java  | 21 +++++++++++++----
 .../security/FunctionSecurityPrmsHolder.java    | 21 +++++++++++++----
 .../security/LdapUserAuthenticator.java         | 21 +++++++++++++----
 .../java/templates/security/PKCSAuthInit.java   | 21 +++++++++++++----
 .../templates/security/PKCSAuthenticator.java   | 21 +++++++++++++----
 .../java/templates/security/PKCSPrincipal.java  | 21 +++++++++++++----
 .../security/UserPasswordAuthInit.java          | 21 +++++++++++++----
 .../templates/security/UsernamePrincipal.java   | 21 +++++++++++++----
 .../templates/security/XmlAuthorization.java    | 21 +++++++++++++----
 .../templates/security/XmlErrorHandler.java     | 21 +++++++++++++----
 .../org/jgroups/ShunnedAddressException.java    | 16 +++++++++++++
 .../com/gemstone/org/jgroups/SuspectMember.java | 16 ++++++++++++-
 .../org/jgroups/debug/JChannelTestHook.java     | 16 +++++++++++++
 .../gemstone/org/jgroups/protocols/AUTH.java    | 16 +++++++++++++
 .../gemstone/org/jgroups/protocols/FRAG3.java   | 17 ++++++++++++--
 .../org/jgroups/spi/GFBasicAdapter.java         | 16 +++++++++++++
 .../gemstone/org/jgroups/spi/GFPeerAdapter.java | 16 +++++++++++++
 .../org/jgroups/stack/GFBasicAdapterImpl.java   | 16 +++++++++++++
 .../org/jgroups/stack/GFPeerAdapterImpl.java    | 16 +++++++++++++
 .../org/jgroups/stack/SockCreatorImpl.java      | 16 +++++++++++++
 .../org/jgroups/util/ConnectionWatcher.java     | 16 +++++++++++++
 .../gemstone/org/jgroups/util/GFLogWriter.java  | 16 +++++++++++++
 .../org/jgroups/util/GFStringIdImpl.java        | 16 +++++++++++++
 .../gemstone/org/jgroups/util/SockCreator.java  | 16 +++++++++++++
 .../org/jgroups/util/StreamableFixedID.java     | 16 +++++++++++++
 .../org/jgroups/util/VersionedStreamable.java   | 16 +++++++++++++
 .../gemstone/org/jgroups/JChannelJUnitTest.java | 16 +++++++++++++
 .../test/junit/categories/DistributedTest.java  | 16 +++++++++++++
 .../categories/DistributedTransactionsTest.java | 16 +++++++++++++
 .../test/junit/categories/HoplogTest.java       | 16 +++++++++++++
 .../test/junit/categories/IntegrationTest.java  | 16 +++++++++++++
 .../test/junit/categories/PerformanceTest.java  | 16 +++++++++++++
 .../gemfire/test/junit/categories/UnitTest.java | 16 +++++++++++++
 .../gemfire/test/junit/categories/WanTest.java  | 16 +++++++++++++
 .../test/junit/rules/ExpectedTimeout.java       | 16 +++++++++++++
 .../junit/rules/ExpectedTimeoutJUnitTest.java   | 16 +++++++++++++
 .../gemfire/cache/util/AutoBalancer.java        | 18 ++++++++++++++-
 .../cache/util/AutoBalancerJUnitTest.java       | 16 +++++++++++++
 .../connector/internal/RegionMetadata.java      | 16 +++++++++++++
 .../gemfirefunctions/QueryFunction.java         | 18 ++++++++++++++-
 .../RetrieveRegionFunction.java                 | 16 +++++++++++++
 .../RetrieveRegionMetadataFunction.java         | 16 +++++++++++++
 .../StructStreamingResultSender.java            | 16 +++++++++++++
 .../gemfire/spark/connector/Employee.java       | 16 +++++++++++++
 .../spark/connector/JavaApiIntegrationTest.java | 16 +++++++++++++
 .../gemfire/spark/connector/Portfolio.java      | 16 +++++++++++++
 .../gemfire/spark/connector/Position.java       | 16 +++++++++++++
 .../javaapi/GemFireJavaDStreamFunctions.java    | 16 +++++++++++++
 .../GemFireJavaPairDStreamFunctions.java        | 16 +++++++++++++
 .../javaapi/GemFireJavaPairRDDFunctions.java    | 16 +++++++++++++
 .../javaapi/GemFireJavaRDDFunctions.java        | 16 +++++++++++++
 .../javaapi/GemFireJavaSQLContextFunctions.java | 16 +++++++++++++
 .../GemFireJavaSparkContextFunctions.java       | 16 +++++++++++++
 .../connector/javaapi/GemFireJavaUtil.java      | 16 +++++++++++++
 .../gemfire/spark/connector/JavaAPITest.java    | 18 ++++++++++++++-
 .../basic-demos/src/main/java/demo/Emp.java     | 16 +++++++++++++
 .../src/main/java/demo/OQLJavaDemo.java         | 16 +++++++++++++
 .../src/main/java/demo/PairRDDSaveJavaDemo.java | 16 +++++++++++++
 .../src/main/java/demo/RDDSaveJavaDemo.java     | 16 +++++++++++++
 .../src/main/java/demo/RegionToRDDJavaDemo.java | 16 +++++++++++++
 .../src/main/scala/demo/NetworkWordCount.scala  | 16 +++++++++++++
 585 files changed, 9363 insertions(+), 210 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/OutOfOffHeapMemoryException.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/OutOfOffHeapMemoryException.java b/gemfire-core/src/main/java/com/gemstone/gemfire/OutOfOffHeapMemoryException.java
index 3909552..424d131 100755
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/OutOfOffHeapMemoryException.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/OutOfOffHeapMemoryException.java
@@ -1,9 +1,18 @@
-/*=========================================================================
- * Copyright (c) 2010-2011 VMware, Inc. All rights reserved.
- * This product is protected by U.S. and international copyright
- * and intellectual property laws. VMware products are covered by
- * one or more patents listed at http://www.vmware.com/go/patents.
- *=========================================================================
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
  */
 package com.gemstone.gemfire;
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/FlushObserver.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/FlushObserver.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/FlushObserver.java
index f0801fe..0725c59 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/FlushObserver.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/FlushObserver.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal;
 
 import java.util.concurrent.TimeUnit;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/QueuedPersistentEvent.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/QueuedPersistentEvent.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/QueuedPersistentEvent.java
index d679003..bd7994c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/QueuedPersistentEvent.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/QueuedPersistentEvent.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal;
 
 import java.io.DataOutput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/SignalledFlushObserver.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/SignalledFlushObserver.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/SignalledFlushObserver.java
index b9b1948..956dd2c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/SignalledFlushObserver.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/SignalledFlushObserver.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/FlushStatus.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/FlushStatus.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/FlushStatus.java
index f75cdba..8fbfe92 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/FlushStatus.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/FlushStatus.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal.hoplog;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueArgs.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueArgs.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueArgs.java
index 0e620d7..aca711c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueArgs.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueArgs.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal.hoplog;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueFunction.java
index a0f648c..cdf7452 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/hdfs/internal/hoplog/HDFSFlushQueueFunction.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.hdfs.internal.hoplog;
 
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
index 0579eef..6bc6428 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQuery.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
index 5636ea4..e3bdafd 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryFactory.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import org.apache.lucene.analysis.Analyzer;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
index d660a4b..cc8d6cf 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneQueryResults.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
index a5b16b7..0cede8b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneResultStruct.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import java.util.LinkedList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
index dde54bf..f4fbd76 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneService.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceFactory.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceFactory.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceFactory.java
index 637f1c0..66e6d42 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceFactory.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceFactory.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import com.gemstone.gemfire.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
index 27395ab..067364b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/LuceneServiceProvider.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene;
 
 import java.util.Iterator;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
index a7bdd99..ae59b99 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneIndexImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.HashSet;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
index 3bd5b0c..ec729dc 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryFactoryImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.HashSet;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
index 04025d3..23c0344 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.Set;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
index ecb6370..af22504 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneQueryResultsImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
index 0db8f97..7e9eb2e 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneResultStructImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.LinkedList;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceFactoryImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceFactoryImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceFactoryImpl.java
index d506f7a..93dbf3d 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceFactoryImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceFactoryImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import com.gemstone.gemfire.cache.Cache;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
index ed90f89..bf7f06b 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/lucene/internal/LuceneServiceImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.lucene.internal;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/operations/internal/GetOperationContextImpl.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/operations/internal/GetOperationContextImpl.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/operations/internal/GetOperationContextImpl.java
index 7772c84..fd2a944 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/operations/internal/GetOperationContextImpl.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/operations/internal/GetOperationContextImpl.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.operations.internal;
 
 import com.gemstone.gemfire.SerializationException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/Aggregator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/Aggregator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/Aggregator.java
index 9f54eba..c906378 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/Aggregator.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/Aggregator.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledAggregateFunction.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledAggregateFunction.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledAggregateFunction.java
index ba77310..c17483c 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledAggregateFunction.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledAggregateFunction.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import com.gemstone.gemfire.cache.query.AmbiguousNameException;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledGroupBySelect.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledGroupBySelect.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledGroupBySelect.java
index ad41c30..fe679b9 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledGroupBySelect.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CompiledGroupBySelect.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CumulativeNonDistinctResults.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CumulativeNonDistinctResults.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CumulativeNonDistinctResults.java
index b8273e5..3735956 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CumulativeNonDistinctResults.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/CumulativeNonDistinctResults.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/NWayMergeResults.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/NWayMergeResults.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/NWayMergeResults.java
index eb54a1c..8865ef1 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/NWayMergeResults.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/NWayMergeResults.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparator.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparator.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparator.java
index 3b6a6f0..cd1954e 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparator.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparator.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import java.util.Comparator;
@@ -218,4 +234,4 @@ public class OrderByComparator implements Comparator {
     // No op
   }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparatorUnmapped.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparatorUnmapped.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparatorUnmapped.java
index 7b9af53..6eb8c46 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparatorUnmapped.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/OrderByComparatorUnmapped.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import it.unimi.dsi.fastutil.objects.Object2ObjectOpenCustomHashMap;

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/b7b08d1c/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/Ordered.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/Ordered.java b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/Ordered.java
index 3c60a82..2fc502e 100644
--- a/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/Ordered.java
+++ b/gemfire-core/src/main/java/com/gemstone/gemfire/cache/query/internal/Ordered.java
@@ -1,3 +1,19 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
 package com.gemstone.gemfire.cache.query.internal;
 
 import java.util.Comparator;