You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@wayang.apache.org by be...@apache.org on 2021/02/06 17:27:51 UTC

[incubator-wayang] branch main updated (5f3acb9 -> 086f6a0)

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

bertty pushed a change to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git.


    from 5f3acb9  minnor correction on the rebranding
     new 8689cc1  Add DISCLAIMER
     new 7f71ec5  Add header licence to files in wayang-api
     new cb96db9  Add header licence to files in wayang-distro
     new 851429d  Add header licence to files in wayang-basic
     new e3d1116  Add header licence to files in wayang-core
     new a5aa26f  Add header licence to files in wayang-extensions
     new ea0cac8  Add header licence to files in wayang-flink
     new 5022a42  Add header licence to files in wayang-giraph
     new 41651f3  Add header licence to files in wayang-graphchi
     new 4d19faa  Add header licence to files in wayang-java
     new 423cd4b  Add header licence to files in wayang-postgres
     new 7e1808f  Add header licence to files in wayang-jdbc-template
     new c5a0edb  Add header licence to files in wayang-spark
     new 260e6d2  Add header licence to files in wayang-sqlite3
     new fe798bf  Add header licence to files in wayang-profiler
     new 086f6a0  Add header licence to files in wayang-test

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


Summary of changes:
 DISCLAIMER                                            |  7 +++++++
 pom.xml                                               | 11 +++++++++++
 wayang-api/pom.xml                                    | 12 ++++++++++++
 .../main/scala/org/apache/wayang/api/DataQuanta.scala | 18 ++++++++++++++++++
 .../org/apache/wayang/api/DataQuantaBuilder.scala     | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/JavaPlanBuilder.scala | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/PlanBuilder.scala     | 18 ++++++++++++++++++
 .../org/apache/wayang/api/RecordDataQuanta.scala      | 18 ++++++++++++++++++
 .../apache/wayang/api/RecordDataQuantaBuilder.scala   | 18 ++++++++++++++++++
 .../main/scala/org/apache/wayang/api/graph/Edge.scala | 18 ++++++++++++++++++
 .../org/apache/wayang/api/graph/EdgeDataQuanta.scala  | 18 ++++++++++++++++++
 .../wayang/api/graph/EdgeDataQuantaBuilder.scala      | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/graph/package.scala   | 18 ++++++++++++++++++
 .../main/scala/org/apache/wayang/api/package.scala    | 18 ++++++++++++++++++
 .../wayang/api/util/DataQuantaBuilderCache.scala      | 18 ++++++++++++++++++
 .../wayang/api/util/DataQuantaBuilderDecorator.scala  | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/util/TypeTrap.scala   | 18 ++++++++++++++++++
 .../test/java/org/apache/wayang/api/JavaApiTest.java  | 18 ++++++++++++++++++
 .../test/scala/org/apache/wayang/api/ApiTest.scala    | 18 ++++++++++++++++++
 wayang-basic/pom.xml                                  | 11 +++++++++++
 .../java/org/apache/wayang/basic/WayangBasics.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/channels/FileChannel.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Record.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Tuple2.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Tuple5.java     | 18 ++++++++++++++++++
 .../wayang/basic/function/ProjectionDescriptor.java   | 18 ++++++++++++++++++
 .../wayang/basic/mapping/GlobalReduceMapping.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/mapping/Mappings.java     | 18 ++++++++++++++++++
 .../basic/mapping/MaterializedGroupByMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/PageRankMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/ReduceByMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/RepeatMapping.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/CartesianOperator.java     | 18 ++++++++++++++++++
 .../wayang/basic/operators/CoGroupOperator.java       | 18 ++++++++++++++++++
 .../wayang/basic/operators/CollectionSource.java      | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/CountOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/DistinctOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/DoWhileOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/FilterOperator.java | 18 ++++++++++++++++++
 .../wayang/basic/operators/FlatMapOperator.java       | 18 ++++++++++++++++++
 .../operators/GlobalMaterializedGroupOperator.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/GlobalReduceOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/GroupByOperator.java       | 18 ++++++++++++++++++
 .../wayang/basic/operators/IntersectOperator.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/JoinOperator.java   | 18 ++++++++++++++++++
 .../wayang/basic/operators/LocalCallbackSink.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/LoopOperator.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/MapOperator.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/MapPartitionsOperator.java | 18 ++++++++++++++++++
 .../basic/operators/MaterializedGroupByOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/PageRankOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/ReduceByOperator.java      | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/ReduceOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/RepeatOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/SampleOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/SortOperator.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TableSource.java    | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TextFileSink.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TextFileSource.java | 18 ++++++++++++++++++
 .../wayang/basic/operators/UnionAllOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/ZipWithIdOperator.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/plugin/WayangBasic.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/plugin/WayangBasicGraph.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/types/RecordType.java     | 19 ++++++++++++++++++-
 .../basic/function/ProjectionDescriptorTest.java      | 18 ++++++++++++++++++
 .../wayang/basic/mapping/ReduceByMappingTest.java     | 18 ++++++++++++++++++
 .../operators/MaterializedGroupByOperatorTest.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/TextFileSourceTest.java    | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/test/TestSink.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/test/TestSource.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/types/RecordTypeTest.java | 18 ++++++++++++++++++
 wayang-core/pom.xml                                   | 11 +++++++++++
 .../antlr4/org/apache/wayang/core/mathex/MathEx.g4    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/api/Configuration.java     | 18 ++++++++++++++++++
 .../src/main/java/org/apache/wayang/core/api/Job.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/api/WayangContext.java     | 18 ++++++++++++++++++
 .../core/api/configuration/CollectionProvider.java    | 18 ++++++++++++++++++
 .../core/api/configuration/ConstantValueProvider.java | 18 ++++++++++++++++++
 .../api/configuration/ExplicitCollectionProvider.java | 18 ++++++++++++++++++
 .../configuration/FunctionalCollectionProvider.java   | 18 ++++++++++++++++++
 .../api/configuration/FunctionalKeyValueProvider.java | 18 ++++++++++++++++++
 .../api/configuration/FunctionalValueProvider.java    | 18 ++++++++++++++++++
 .../core/api/configuration/KeyValueProvider.java      | 18 ++++++++++++++++++
 .../api/configuration/MapBasedKeyValueProvider.java   | 18 ++++++++++++++++++
 .../wayang/core/api/configuration/ValueProvider.java  | 18 ++++++++++++++++++
 .../wayang/core/api/exception/WayangException.java    | 18 ++++++++++++++++++
 .../wayang/core/function/AggregationDescriptor.java   | 18 ++++++++++++++++++
 .../wayang/core/function/ConsumerDescriptor.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ExecutionContext.java | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ExtendedFunction.java | 18 ++++++++++++++++++
 .../wayang/core/function/FlatMapDescriptor.java       | 18 ++++++++++++++++++
 .../wayang/core/function/FunctionDescriptor.java      | 18 ++++++++++++++++++
 .../wayang/core/function/MapPartitionsDescriptor.java | 18 ++++++++++++++++++
 .../wayang/core/function/PredicateDescriptor.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ReduceDescriptor.java | 18 ++++++++++++++++++
 .../core/function/TransformationDescriptor.java       | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/mapping/Mapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/mapping/OperatorMatch.java | 18 ++++++++++++++++++
 .../apache/wayang/core/mapping/OperatorPattern.java   | 18 ++++++++++++++++++
 .../wayang/core/mapping/PlanTransformation.java       | 18 ++++++++++++++++++
 .../core/mapping/ReplacementSubplanFactory.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/core/mapping/SubplanMatch.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/mapping/SubplanPattern.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/monitor/DisabledMonitor.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/FileMonitor.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/HttpMonitor.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/monitor/Monitor.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/ZeroMQMonitor.java | 18 ++++++++++++++++++
 .../core/optimizer/AggregateOptimizationContext.java  | 18 ++++++++++++++++++
 .../core/optimizer/DefaultOptimizationContext.java    | 18 ++++++++++++++++++
 .../wayang/core/optimizer/OptimizationContext.java    | 18 ++++++++++++++++++
 .../wayang/core/optimizer/OptimizationUtils.java      | 18 ++++++++++++++++++
 .../core/optimizer/ProbabilisticDoubleInterval.java   | 18 ++++++++++++++++++
 .../core/optimizer/ProbabilisticIntervalEstimate.java | 18 ++++++++++++++++++
 .../apache/wayang/core/optimizer/SanityChecker.java   | 18 ++++++++++++++++++
 .../AbstractAlternativeCardinalityPusher.java         | 18 ++++++++++++++++++
 .../cardinality/AggregatingCardinalityEstimator.java  | 18 ++++++++++++++++++
 .../optimizer/cardinality/CardinalityEstimate.java    | 18 ++++++++++++++++++
 .../cardinality/CardinalityEstimationTraversal.java   | 18 ++++++++++++++++++
 .../optimizer/cardinality/CardinalityEstimator.java   | 18 ++++++++++++++++++
 .../cardinality/CardinalityEstimatorManager.java      | 18 ++++++++++++++++++
 .../core/optimizer/cardinality/CardinalityPusher.java | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityEstimator.java      | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityPusher.java         | 18 ++++++++++++++++++
 .../cardinality/FallbackCardinalityEstimator.java     | 18 ++++++++++++++++++
 .../cardinality/FixedSizeCardinalityEstimator.java    | 18 ++++++++++++++++++
 .../LoopHeadAlternativeCardinalityPusher.java         | 18 ++++++++++++++++++
 .../cardinality/LoopSubplanCardinalityPusher.java     | 18 ++++++++++++++++++
 .../OperatorAlternativeCardinalityPusher.java         | 18 ++++++++++++++++++
 .../cardinality/SubplanCardinalityPusher.java         | 18 ++++++++++++++++++
 .../SwitchForwardCardinalityEstimator.java            | 18 ++++++++++++++++++
 .../core/optimizer/channels/ChannelConversion.java    | 18 ++++++++++++++++++
 .../optimizer/channels/ChannelConversionGraph.java    | 18 ++++++++++++++++++
 .../optimizer/channels/DefaultChannelConversion.java  | 18 ++++++++++++++++++
 .../optimizer/costs/ConstantLoadProfileEstimator.java | 18 ++++++++++++++++++
 .../core/optimizer/costs/DefaultLoadEstimator.java    | 18 ++++++++++++++++++
 .../core/optimizer/costs/EstimationContext.java       | 18 ++++++++++++++++++
 .../core/optimizer/costs/IntervalLoadEstimator.java   | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadEstimate.java     | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadEstimator.java    | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadProfile.java      | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadProfileEstimator.java    | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadProfileEstimators.java   | 18 ++++++++++++++++++
 .../optimizer/costs/LoadProfileToTimeConverter.java   | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadToTimeConverter.java     | 18 ++++++++++++++++++
 .../optimizer/costs/NestableLoadProfileEstimator.java | 18 ++++++++++++++++++
 .../core/optimizer/costs/SimpleEstimationContext.java | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/TimeEstimate.java     | 18 ++++++++++++++++++
 .../core/optimizer/costs/TimeToCostConverter.java     | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/ExecutionTaskFlow.java | 18 ++++++++++++++++++
 .../enumeration/ExecutionTaskFlowCompiler.java        | 18 ++++++++++++++++++
 .../enumeration/LatentOperatorPruningStrategy.java    | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/LoopEnumerator.java    | 18 ++++++++++++++++++
 .../optimizer/enumeration/LoopImplementation.java     | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/PlanEnumeration.java   | 18 ++++++++++++++++++
 .../enumeration/PlanEnumerationPruningStrategy.java   | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/PlanEnumerator.java    | 18 ++++++++++++++++++
 .../optimizer/enumeration/PlanImplementation.java     | 18 ++++++++++++++++++
 .../optimizer/enumeration/RandomPruningStrategy.java  | 18 ++++++++++++++++++
 .../enumeration/SinglePlatformPruningStrategy.java    | 18 ++++++++++++++++++
 .../enumeration/StageAssignmentTraversal.java         | 18 ++++++++++++++++++
 .../optimizer/enumeration/TopKPruningStrategy.java    | 18 ++++++++++++++++++
 .../optimizer/partition/EnumerationAlternative.java   | 18 ++++++++++++++++++
 .../core/optimizer/partition/EnumerationBranch.java   | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/Channel.java       | 18 ++++++++++++++++++
 .../core/plan/executionplan/ChannelInitializer.java   | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/ExecutionPlan.java | 18 ++++++++++++++++++
 .../core/plan/executionplan/ExecutionStage.java       | 18 ++++++++++++++++++
 .../core/plan/executionplan/ExecutionStageLoop.java   | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/ExecutionTask.java | 18 ++++++++++++++++++
 .../core/plan/executionplan/PlatformExecution.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/ActualOperator.java   | 18 ++++++++++++++++++
 .../core/plan/wayangplan/BinaryToUnaryOperator.java   | 18 ++++++++++++++++++
 .../core/plan/wayangplan/CompositeOperator.java       | 18 ++++++++++++++++++
 .../core/plan/wayangplan/ElementaryOperator.java      | 18 ++++++++++++++++++
 .../plan/wayangplan/EstimationContextProperty.java    | 18 ++++++++++++++++++
 .../core/plan/wayangplan/ExecutionOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/InputSlot.java | 18 ++++++++++++++++++
 .../core/plan/wayangplan/LoopHeadAlternative.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopHeadOperator.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopIsolator.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopSubplan.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Operator.java  | 18 ++++++++++++++++++
 .../core/plan/wayangplan/OperatorAlternative.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OperatorBase.java     | 18 ++++++++++++++++++
 .../core/plan/wayangplan/OperatorContainer.java       | 18 ++++++++++++++++++
 .../core/plan/wayangplan/OperatorContainers.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Operators.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OutputSlot.java       | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/PlanMetrics.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/PlanTraversal.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/plan/wayangplan/Slot.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/SlotMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Subplan.java   | 18 ++++++++++++++++++
 .../core/plan/wayangplan/TopDownPlanVisitor.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/UnarySink.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/UnarySource.java      | 18 ++++++++++++++++++
 .../core/plan/wayangplan/UnaryToUnaryOperator.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/WayangPlan.java       | 18 ++++++++++++++++++
 .../traversal/AbstractTopologicalTraversal.java       | 18 ++++++++++++++++++
 .../wayang/core/platform/AbstractChannelInstance.java | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/AtomicExecution.java  | 18 ++++++++++++++++++
 .../wayang/core/platform/AtomicExecutionGroup.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/Breakpoint.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/CardinalityBreakpoint.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/ChannelDescriptor.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ChannelInstance.java  | 18 ++++++++++++++++++
 .../core/platform/CompositeExecutionResource.java     | 18 ++++++++++++++++++
 .../wayang/core/platform/ConjunctiveBreakpoint.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/CrossPlatformExecutor.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/ExecutionResource.java       | 18 ++++++++++++++++++
 .../core/platform/ExecutionResourceTemplate.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ExecutionState.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/Executor.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ExecutorTemplate.java | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/FixBreakpoint.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/Junction.java     | 18 ++++++++++++++++++
 .../wayang/core/platform/NoIterationBreakpoint.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/PartialExecution.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/Platform.java     | 18 ++++++++++++++++++
 .../wayang/core/platform/PushExecutorTemplate.java    | 18 ++++++++++++++++++
 .../core/platform/lineage/ChannelLineageNode.java     | 18 ++++++++++++++++++
 .../core/platform/lineage/ExecutionLineageNode.java   | 18 ++++++++++++++++++
 .../platform/lineage/LazyExecutionLineageNode.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/plugin/DynamicPlugin.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/plugin/Plugin.java    | 18 ++++++++++++++++++
 .../wayang/core/profiling/CardinalityRepository.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/profiling/CostMeasurement.java | 18 ++++++++++++++++++
 .../apache/wayang/core/profiling/ExecutionLog.java    | 18 ++++++++++++++++++
 .../core/profiling/ExecutionPlanMeasurement.java      | 18 ++++++++++++++++++
 .../core/profiling/FullInstrumentationStrategy.java   | 18 ++++++++++++++++++
 .../core/profiling/InstrumentationStrategy.java       | 18 ++++++++++++++++++
 .../core/profiling/NoInstrumentationStrategy.java     | 18 ++++++++++++++++++
 .../profiling/OutboundInstrumentationStrategy.java    | 18 ++++++++++++++++++
 .../core/profiling/PartialExecutionMeasurement.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/profiling/ProfileDBs.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/types/BasicDataUnitType.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/types/DataSetType.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/types/DataUnitGroupType.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/types/DataUnitType.java    | 18 ++++++++++++++++++
 .../wayang/core/util/AbstractReferenceCountable.java  | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Action.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Actions.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Bitmask.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/Canonicalizer.java    | 18 ++++++++++++++++++
 .../wayang/core/util/ConsumerIteratorAdapter.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Copyable.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Counter.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/util/CrossProductIterable.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Formats.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Iterators.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/JsonSerializable.java | 18 ++++++++++++++++++
 .../apache/wayang/core/util/JsonSerializables.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/JsonSerializer.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/JuelUtils.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/util/LimitedInputStream.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Logging.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/LruCache.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/MultiMap.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/util/OneTimeExecutable.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Optional.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/util/ReferenceCountable.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/ReflectionUtils.java  | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Tuple.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/WayangArrays.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/util/WayangCollections.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/fs/FileSystem.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/fs/FileSystems.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/fs/FileUtils.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/util/fs/HadoopFileSystem.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/util/fs/LocalFileSystem.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/mathex/Context.java   | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/DefaultContext.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/util/mathex/Expression.java    | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/ExpressionBuilder.java    | 18 ++++++++++++++++++
 .../util/mathex/exceptions/EvaluationException.java   | 18 ++++++++++++++++++
 .../core/util/mathex/exceptions/MathExException.java  | 18 ++++++++++++++++++
 .../core/util/mathex/exceptions/ParseException.java   | 18 ++++++++++++++++++
 .../core/util/mathex/model/BinaryOperation.java       | 18 ++++++++++++++++++
 .../core/util/mathex/model/CompiledFunction.java      | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/Constant.java       | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/NamedFunction.java  | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/UnaryOperation.java | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/Variable.java       | 18 ++++++++++++++++++
 .../test/java/org/apache/wayang/core/SlotTest.java    | 18 ++++++++++++++++++
 .../wayang/core/mapping/OperatorPatternTest.java      | 18 ++++++++++++++++++
 .../wayang/core/mapping/PlanTransformationTest.java   | 18 ++++++++++++++++++
 .../wayang/core/mapping/SubplanPatternTest.java       | 18 ++++++++++++++++++
 .../wayang/core/mapping/test/TestSinkMapping.java     | 18 ++++++++++++++++++
 .../core/mapping/test/TestSinkToTestSink2Factory.java | 18 ++++++++++++++++++
 .../AggregatingCardinalityEstimatorTest.java          | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityEstimatorTest.java  | 18 ++++++++++++++++++
 .../cardinality/LoopSubplanCardinalityPusherTest.java | 18 ++++++++++++++++++
 .../cardinality/SubplanCardinalityPusherTest.java     | 18 ++++++++++++++++++
 .../channels/ChannelConversionGraphTest.java          | 18 ++++++++++++++++++
 .../costs/NestableLoadProfileEstimatorTest.java       | 18 ++++++++++++++++++
 .../enumeration/StageAssignmentTraversalTest.java     | 18 ++++++++++++++++++
 .../core/plan/executionplan/test/TestChannel.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopIsolatorTest.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OperatorTest.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/SlotMappingTest.java  | 18 ++++++++++++++++++
 .../plan/wayangplan/test/TestCustomMapOperator.java   | 18 ++++++++++++++++++
 .../core/plan/wayangplan/test/TestFilterOperator.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestJoin.java    | 18 ++++++++++++++++++
 .../core/plan/wayangplan/test/TestLoopHead.java       | 18 ++++++++++++++++++
 .../core/plan/wayangplan/test/TestMapOperator.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSink.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSink2.java   | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSource.java  | 18 ++++++++++++++++++
 .../wayang/core/platform/PartialExecutionTest.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/plugin/DynamicPluginTest.java  | 18 ++++++++++++++++++
 .../wayang/core/test/DummyExecutionOperator.java      | 18 ++++++++++++++++++
 .../core/test/DummyExternalReusableChannel.java       | 18 ++++++++++++++++++
 .../wayang/core/test/DummyNonReusableChannel.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/test/DummyPlatform.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/test/DummyReusableChannel.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/test/MockFactory.java | 18 ++++++++++++++++++
 .../core/test/SerializableDummyExecutionOperator.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/test/TestDataUnit.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/test/TestDataUnit2.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/BitmaskTest.java | 18 ++++++++++++++++++
 .../wayang/core/util/ConsumerIteratorAdapterTest.java | 18 ++++++++++++++++++
 .../wayang/core/util/CrossProductIterableTest.java    | 18 ++++++++++++++++++
 .../wayang/core/util/LimitedInputStreamTest.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/util/ReflectionUtilsTest.java  | 18 ++++++++++++++++++
 .../wayang/core/util/WayangCollectionsTest.java       | 18 ++++++++++++++++++
 .../core/util/mathex/ExpressionBuilderTest.java       | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/ExpressionTest.java       | 18 ++++++++++++++++++
 wayang-distro/pom.xml                                 | 11 +++++++++++
 wayang-distro/src/assembly/distro.xml                 | 11 +++++++++++
 wayang-extensions/pom.xml                             | 11 +++++++++++
 wayang-extensions/wayang-iejoin/pom.xml               | 11 +++++++++++
 .../main/java/org/apache/wayang/iejoin/IEJoin.java    | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/iejoin/data/Data.java | 18 ++++++++++++++++++
 .../org/apache/wayang/iejoin/mapping/Mappings.java    | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/java/IEJoinMapping.java     | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/java/IESelfJoinMapping.java | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/spark/IEJoinMapping.java    | 18 ++++++++++++++++++
 .../iejoin/mapping/spark/IESelfJoinMapping.java       | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/IEJoinMasterOperator.java | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/IEJoinOperator.java       | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/IESelfJoinOperator.java   | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/JavaIEJoinOperator.java   | 18 ++++++++++++++++++
 .../iejoin/operators/JavaIESelfJoinOperator.java      | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/SparkIEJoinOperator.java  | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIESelfJoinOperator.java     | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/BitSetJoin.java     | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/DataComparator.java | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/extractData.java    | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/myMergeSort.java    | 18 ++++++++++++++++++
 .../operators/java_helpers/revDataComparator.java     | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/BitSetJoin.java    | 18 ++++++++++++++++++
 .../spark_helpers/List2AttributesObjectSkinny.java    | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/addUniqueID.java   | 18 ++++++++++++++++++
 .../operators/spark_helpers/build2ListObject.java     | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/extractData.java   | 18 ++++++++++++++++++
 .../operators/spark_helpers/filterUnwantedBlocks.java | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/myMergeSort.java   | 18 ++++++++++++++++++
 .../operators/spark_helpers/revDataComparator.java    | 18 ++++++++++++++++++
 .../operators/JavaExecutionOperatorTestBase.java      | 18 ++++++++++++++++++
 .../iejoin/operators/JavaIEJoinOperatorTest.java      | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest.java     | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest2.java    | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest3.java    | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest4.java    | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIESelfJoinOperatorTest.java | 18 ++++++++++++++++++
 .../iejoin/operators/SparkOperatorTestBase.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/iejoin/test/ChannelFactory.java | 18 ++++++++++++++++++
 wayang-platforms/pom.xml                              | 11 +++++++++++
 wayang-platforms/wayang-flink/pom.xml                 | 11 +++++++++++
 .../src/main/java/org/apache/wayang/flink/Flink.java  | 18 ++++++++++++++++++
 .../wayang/flink/channels/ChannelConversions.java     | 18 ++++++++++++++++++
 .../apache/wayang/flink/channels/DataSetChannel.java  | 18 ++++++++++++++++++
 .../wayang/flink/compiler/FlinkCoGroupFunction.java   | 18 ++++++++++++++++++
 .../wayang/flink/compiler/FunctionCompiler.java       | 18 ++++++++++++++++++
 .../wayang/flink/compiler/KeySelectorDistinct.java    | 18 ++++++++++++++++++
 .../wayang/flink/compiler/KeySelectorFunction.java    | 18 ++++++++++++++++++
 .../wayang/flink/compiler/OutputFormatConsumer.java   | 18 ++++++++++++++++++
 .../wayang/flink/compiler/WayangFileOutputFormat.java | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/DummyFilter.java  | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/DummyMap.java     | 18 ++++++++++++++++++
 .../flink/compiler/criterion/WayangAggregator.java    | 18 ++++++++++++++++++
 .../criterion/WayangConvergenceCriterion.java         | 18 ++++++++++++++++++
 .../compiler/criterion/WayangFilterCriterion.java     | 18 ++++++++++++++++++
 .../flink/compiler/criterion/WayangListValue.java     | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/WayangValue.java  | 18 ++++++++++++++++++
 .../wayang/flink/execution/FlinkContextReference.java | 18 ++++++++++++++++++
 .../wayang/flink/execution/FlinkExecutionContext.java | 18 ++++++++++++++++++
 .../apache/wayang/flink/execution/FlinkExecutor.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/CartesianMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/CoGroupMapping.java   | 18 ++++++++++++++++++
 .../wayang/flink/mapping/CollectionSourceMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/CountMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/DistinctMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/DoWhileMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/FilterMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/FlatMapMapping.java   | 18 ++++++++++++++++++
 .../flink/mapping/GlobalMaterializedGroupMapping.java | 18 ++++++++++++++++++
 .../wayang/flink/mapping/GlobalReduceMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/GroupByMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/IntersectMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/JoinMapping.java  | 18 ++++++++++++++++++
 .../flink/mapping/LocalCallbackSinkMapping.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/LoopMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/MapMapping.java   | 18 ++++++++++++++++++
 .../wayang/flink/mapping/MapPartitionsMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/Mappings.java     | 18 ++++++++++++++++++
 .../flink/mapping/MaterializedGroupByMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/PageRankMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/ReduceByMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/RepeatMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/SampleMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/SortMapping.java  | 18 ++++++++++++++++++
 .../wayang/flink/mapping/TextFileSinkMapping.java     | 18 ++++++++++++++++++
 .../wayang/flink/mapping/TextFileSourceMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/UnionAllMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/ZipWithIdMapping.java | 18 ++++++++++++++++++
 .../flink/operators/FlinkCartesianOperator.java       | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCoGroupOperator.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCollectionSink.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCollectionSource.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCountOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkDistinctOperator.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkDoWhileOperator.java  | 18 ++++++++++++++++++
 .../flink/operators/FlinkExecutionOperator.java       | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkFilterOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkFlatMapOperator.java  | 18 ++++++++++++++++++
 .../FlinkGlobalMaterializedGroupOperator.java         | 18 ++++++++++++++++++
 .../flink/operators/FlinkGlobalReduceOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkGroupByOperator.java  | 18 ++++++++++++++++++
 .../flink/operators/FlinkIntersectOperator.java       | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkJoinOperator.java     | 18 ++++++++++++++++++
 .../flink/operators/FlinkLocalCallbackSink.java       | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkLoopOperator.java     | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkMapOperator.java      | 18 ++++++++++++++++++
 .../flink/operators/FlinkMapPartitionsOperator.java   | 18 ++++++++++++++++++
 .../operators/FlinkMaterializedGroupByOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkObjectFileSink.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkObjectFileSource.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkPageRankOperator.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkReduceByOperator.java | 18 ++++++++++++++++++
 .../flink/operators/FlinkRepeatExpandedOperator.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkRepeatOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkSampleOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkSortOperator.java     | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTextFileSink.java     | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTextFileSource.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTsvFileSink.java      | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkUnionAllOperator.java | 18 ++++++++++++++++++
 .../flink/operators/FlinkZipWithIdOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/flink/platform/FlinkPlatform.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/plugin/FlinkBasicPlugin.java  | 18 ++++++++++++++++++
 .../wayang/flink/plugin/FlinkConversionPlugin.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/plugin/FlinkGraphPlugin.java  | 18 ++++++++++++++++++
 wayang-platforms/wayang-giraph/pom.xml                | 11 +++++++++++
 .../wayang/giraph/Algorithm/PageRankAlgorithm.java    | 18 ++++++++++++++++++
 .../wayang/giraph/Algorithm/PageRankParameters.java   | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/giraph/Giraph.java    | 18 ++++++++++++++++++
 .../wayang/giraph/channels/ChannelConversions.java    | 18 ++++++++++++++++++
 .../wayang/giraph/execution/GiraphExecutor.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/giraph/mappings/Mappings.java   | 18 ++++++++++++++++++
 .../wayang/giraph/mappings/PageRankMapping.java       | 18 ++++++++++++++++++
 .../giraph/operators/GiraphExecutionOperator.java     | 18 ++++++++++++++++++
 .../giraph/operators/GiraphPageRankOperator.java      | 18 ++++++++++++++++++
 .../apache/wayang/giraph/platform/GiraphPlatform.java | 18 ++++++++++++++++++
 .../org/apache/wayang/giraph/plugin/GiraphPlugin.java | 18 ++++++++++++++++++
 .../giraph/operators/GiraphPagaRankOperatorTest.java  | 18 ++++++++++++++++++
 wayang-platforms/wayang-graphchi/pom.xml              | 11 +++++++++++
 .../java/org/apache/wayang/graphchi/GraphChi.java     | 18 ++++++++++++++++++
 .../wayang/graphchi/channels/ChannelConversions.java  | 18 ++++++++++++++++++
 .../wayang/graphchi/execution/GraphChiExecutor.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/graphchi/mappings/Mappings.java | 18 ++++++++++++++++++
 .../wayang/graphchi/mappings/PageRankMapping.java     | 18 ++++++++++++++++++
 .../graphchi/operators/GraphChiExecutionOperator.java | 18 ++++++++++++++++++
 .../graphchi/operators/GraphChiPageRankOperator.java  | 18 ++++++++++++++++++
 .../wayang/graphchi/platform/GraphChiPlatform.java    | 18 ++++++++++++++++++
 .../apache/wayang/graphchi/plugin/GraphChiPlugin.java | 18 ++++++++++++++++++
 .../operators/GraphChiPageRankOperatorTest.java       | 18 ++++++++++++++++++
 wayang-platforms/wayang-java/pom.xml                  | 11 +++++++++++
 .../src/main/java/org/apache/wayang/java/Java.java    | 18 ++++++++++++++++++
 .../wayang/java/channels/ChannelConversions.java      | 18 ++++++++++++++++++
 .../wayang/java/channels/CollectionChannel.java       | 18 ++++++++++++++++++
 .../wayang/java/channels/JavaChannelInstance.java     | 18 ++++++++++++++++++
 .../apache/wayang/java/channels/StreamChannel.java    | 18 ++++++++++++++++++
 .../apache/wayang/java/compiler/FunctionCompiler.java | 18 ++++++++++++++++++
 .../wayang/java/execution/JavaExecutionContext.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/execution/JavaExecutor.java    | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/CartesianMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/CoGroupMapping.java    | 18 ++++++++++++++++++
 .../wayang/java/mapping/CollectionSourceMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/CountMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/DistinctMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/DoWhileMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/FilterMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/FlatMapMapping.java    | 18 ++++++++++++++++++
 .../java/mapping/GlobalMaterializedGroupMapping.java  | 18 ++++++++++++++++++
 .../wayang/java/mapping/GlobalReduceMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/IntersectMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/JoinMapping.java   | 18 ++++++++++++++++++
 .../wayang/java/mapping/LocalCallbackSinkMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/LoopMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/MapMapping.java    | 18 ++++++++++++++++++
 .../wayang/java/mapping/MapPartitionsMapping.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/java/mapping/Mappings.java | 18 ++++++++++++++++++
 .../java/mapping/MaterializedGroupByMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/ReduceByMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/RepeatMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/SampleMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/SortMapping.java   | 18 ++++++++++++++++++
 .../wayang/java/mapping/TextFileSinkMapping.java      | 18 ++++++++++++++++++
 .../wayang/java/mapping/TextFileSourceMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/UnionAllMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/ZipWithIdMapping.java  | 18 ++++++++++++++++++
 .../wayang/java/mapping/graph/PageRankMapping.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCartesianOperator.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCoGroupOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCollectOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCollectionSource.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCountOperator.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaDistinctOperator.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaDoWhileOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaExecutionOperator.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFilterOperator.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFlatMapOperator.java    | 18 ++++++++++++++++++
 .../JavaGlobalMaterializedGroupOperator.java          | 18 ++++++++++++++++++
 .../java/operators/JavaGlobalReduceOperator.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaIntersectOperator.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaJoinOperator.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaLocalCallbackSink.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaLoopOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaMapOperator.java | 18 ++++++++++++++++++
 .../java/operators/JavaMapPartitionsOperator.java     | 18 ++++++++++++++++++
 .../operators/JavaMaterializedGroupByOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSink.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSource.java   | 18 ++++++++++++++++++
 .../java/operators/JavaRandomSampleOperator.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaReduceByOperator.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaRepeatOperator.java     | 18 ++++++++++++++++++
 .../java/operators/JavaReservoirSampleOperator.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaSortOperator.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTextFileSink.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTextFileSource.java     | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaTsvFileSink.java | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTsvFileSource.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaUnionAllOperator.java   | 18 ++++++++++++++++++
 .../java/operators/graph/JavaPageRankOperator.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/platform/JavaPlatform.java | 18 ++++++++++++++++++
 .../apache/wayang/java/plugin/JavaBasicPlugin.java    | 18 ++++++++++++++++++
 .../java/plugin/JavaChannelConversionPlugin.java      | 18 ++++++++++++++++++
 .../apache/wayang/java/plugin/JavaGraphPlugin.java    | 18 ++++++++++++++++++
 .../wayang/java/execution/JavaExecutorTest.java       | 18 ++++++++++++++++++
 .../java/operators/JavaCartesianOperatorTest.java     | 18 ++++++++++++++++++
 .../java/operators/JavaCoGroupOperatorTest.java       | 18 ++++++++++++++++++
 .../java/operators/JavaCollectionSourceTest.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCountOperatorTest.java  | 18 ++++++++++++++++++
 .../java/operators/JavaDistinctOperatorTest.java      | 18 ++++++++++++++++++
 .../java/operators/JavaExecutionOperatorTestBase.java | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFilterOperatorTest.java | 18 ++++++++++++++++++
 .../JavaGlobalMaterializedGroupOperatorTest.java      | 18 ++++++++++++++++++
 .../java/operators/JavaGlobalReduceOperatorTest.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaJoinOperatorTest.java   | 18 ++++++++++++++++++
 .../java/operators/JavaLocalCallbackSinkTest.java     | 18 ++++++++++++++++++
 .../JavaMaterializedGroupByOperatorTest.java          | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSinkTest.java | 18 ++++++++++++++++++
 .../java/operators/JavaObjectFileSourceTest.java      | 18 ++++++++++++++++++
 .../java/operators/JavaRandomSampleOperatorTest.java  | 18 ++++++++++++++++++
 .../java/operators/JavaReduceByOperatorTest.java      | 18 ++++++++++++++++++
 .../operators/JavaReservoirSampleOperatorTest.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaSortOperatorTest.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTextFileSinkTest.java   | 18 ++++++++++++++++++
 .../java/operators/JavaUnionAllOperatorTest.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/java/test/ChannelFactory.java   | 18 ++++++++++++++++++
 wayang-platforms/wayang-jdbc-template/pom.xml         | 11 +++++++++++
 .../apache/wayang/jdbc/channels/SqlQueryChannel.java  | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/compiler/FunctionCompiler.java | 18 ++++++++++++++++++
 .../wayang/jdbc/execution/DatabaseDescriptor.java     | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/execution/JdbcExecutor.java    | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcExecutionOperator.java  | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcFilterOperator.java     | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcProjectionOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/operators/JdbcTableSource.java | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/SqlToStreamOperator.java    | 18 ++++++++++++++++++
 .../wayang/jdbc/platform/JdbcPlatformTemplate.java    | 18 ++++++++++++++++++
 .../wayang/jdbc/execution/JdbcExecutorTest.java       | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcTableSourceTest.java    | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/OperatorTestBase.java       | 18 ++++++++++++++++++
 .../jdbc/operators/SqlToStreamOperatorTest.java       | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/test/HsqldbFilterOperator.java | 18 ++++++++++++++++++
 .../org/apache/wayang/jdbc/test/HsqldbPlatform.java   | 18 ++++++++++++++++++
 .../wayang/jdbc/test/HsqldbProjectionOperator.java    | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/test/HsqldbTableSource.java    | 18 ++++++++++++++++++
 wayang-platforms/wayang-postgres/pom.xml              | 11 +++++++++++
 .../java/org/apache/wayang/postgres/Postgres.java     | 18 ++++++++++++++++++
 .../wayang/postgres/channels/ChannelConversions.java  | 18 ++++++++++++++++++
 .../apache/wayang/postgres/mapping/FilterMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/postgres/mapping/Mappings.java  | 18 ++++++++++++++++++
 .../wayang/postgres/mapping/ProjectionMapping.java    | 18 ++++++++++++++++++
 .../postgres/operators/PostgresExecutionOperator.java | 18 ++++++++++++++++++
 .../postgres/operators/PostgresFilterOperator.java    | 18 ++++++++++++++++++
 .../operators/PostgresProjectionOperator.java         | 18 ++++++++++++++++++
 .../postgres/operators/PostgresTableSource.java       | 18 ++++++++++++++++++
 .../wayang/postgres/platform/PostgresPlatform.java    | 18 ++++++++++++++++++
 .../postgres/plugin/PostgresConversionsPlugin.java    | 18 ++++++++++++++++++
 .../apache/wayang/postgres/plugin/PostgresPlugin.java | 18 ++++++++++++++++++
 wayang-platforms/wayang-spark/pom.xml                 | 11 +++++++++++
 .../src/main/java/org/apache/wayang/spark/Spark.java  | 18 ++++++++++++++++++
 .../wayang/spark/channels/BroadcastChannel.java       | 18 ++++++++++++++++++
 .../wayang/spark/channels/ChannelConversions.java     | 18 ++++++++++++++++++
 .../apache/wayang/spark/channels/FileChannels.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/channels/RddChannel.java  | 18 ++++++++++++++++++
 .../wayang/spark/compiler/BinaryOperatorAdapter.java  | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedBinaryOperatorAdapter.java | 18 ++++++++++++++++++
 .../compiler/ExtendedFlatMapFunctionAdapter.java      | 18 ++++++++++++++++++
 .../wayang/spark/compiler/ExtendedFunction.java       | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedMapFunctionAdapter.java    | 18 ++++++++++++++++++
 .../ExtendedMapPartitionsFunctionAdapter.java         | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedPredicateAdapater.java     | 18 ++++++++++++++++++
 .../wayang/spark/compiler/FlatMapFunctionAdapter.java | 18 ++++++++++++++++++
 .../wayang/spark/compiler/FunctionCompiler.java       | 18 ++++++++++++++++++
 .../wayang/spark/compiler/MapFunctionAdapter.java     | 18 ++++++++++++++++++
 .../spark/compiler/MapPartitionsFunctionAdapter.java  | 18 ++++++++++++++++++
 .../wayang/spark/compiler/PredicateAdapter.java       | 18 ++++++++++++++++++
 .../wayang/spark/execution/SparkContextReference.java | 18 ++++++++++++++++++
 .../wayang/spark/execution/SparkExecutionContext.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/execution/SparkExecutor.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/CartesianMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/CoGroupMapping.java   | 18 ++++++++++++++++++
 .../wayang/spark/mapping/CollectionSourceMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/CountMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/DistinctMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/DoWhileMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/FilterMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/FlatMapMapping.java   | 18 ++++++++++++++++++
 .../spark/mapping/GlobalMaterializedGroupMapping.java | 18 ++++++++++++++++++
 .../wayang/spark/mapping/GlobalReduceMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/IntersectMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/JoinMapping.java  | 18 ++++++++++++++++++
 .../spark/mapping/LocalCallbackSinkMapping.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/LoopMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/MapMapping.java   | 18 ++++++++++++++++++
 .../wayang/spark/mapping/MapPartitionsMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/Mappings.java     | 18 ++++++++++++++++++
 .../spark/mapping/MaterializedGroupByMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/ReduceByMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/RepeatMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/SampleMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/SortMapping.java  | 18 ++++++++++++++++++
 .../wayang/spark/mapping/TextFileSinkMapping.java     | 18 ++++++++++++++++++
 .../wayang/spark/mapping/TextFileSourceMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/UnionAllMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/ZipWithIdMapping.java | 18 ++++++++++++++++++
 .../wayang/spark/mapping/graph/PageRankMapping.java   | 18 ++++++++++++++++++
 .../spark/operators/SparkBernoulliSampleOperator.java | 18 ++++++++++++++++++
 .../spark/operators/SparkBroadcastOperator.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCacheOperator.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkCartesianOperator.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCoGroupOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCollectOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCollectionSource.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCountOperator.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkDistinctOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkDoWhileOperator.java  | 18 ++++++++++++++++++
 .../spark/operators/SparkExecutionOperator.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkFilterOperator.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkFlatMapOperator.java  | 18 ++++++++++++++++++
 .../SparkGlobalMaterializedGroupOperator.java         | 18 ++++++++++++++++++
 .../spark/operators/SparkGlobalReduceOperator.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkIntersectOperator.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkJoinOperator.java     | 18 ++++++++++++++++++
 .../spark/operators/SparkLocalCallbackSink.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkLoopOperator.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkMapOperator.java      | 18 ++++++++++++++++++
 .../spark/operators/SparkMapPartitionsOperator.java   | 18 ++++++++++++++++++
 .../operators/SparkMaterializedGroupByOperator.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkObjectFileSink.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkObjectFileSource.java | 18 ++++++++++++++++++
 .../operators/SparkRandomPartitionSampleOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkReduceByOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkRepeatOperator.java   | 18 ++++++++++++++++++
 .../SparkShufflePartitionSampleOperator.java          | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkSortOperator.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSink.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSource.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTsvFileSink.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTsvFileSource.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkUnionAllOperator.java | 18 ++++++++++++++++++
 .../spark/operators/SparkZipWithIdOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/spark/platform/SparkPlatform.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/plugin/SparkBasicPlugin.java  | 18 ++++++++++++++++++
 .../wayang/spark/plugin/SparkConversionPlugin.java    | 18 ++++++++++++++++++
 .../apache/wayang/spark/plugin/SparkGraphPlugin.java  | 18 ++++++++++++++++++
 .../spark/operators/graph/SparkPageRankOperator.scala | 18 ++++++++++++++++++
 .../operators/SparkBernoulliSampleOperatorTest.java   | 18 ++++++++++++++++++
 .../spark/operators/SparkCartesianOperatorTest.java   | 18 ++++++++++++++++++
 .../spark/operators/SparkCoGroupOperatorTest.java     | 18 ++++++++++++++++++
 .../spark/operators/SparkCollectionSourceTest.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkCountOperatorTest.java       | 18 ++++++++++++++++++
 .../spark/operators/SparkDistinctOperatorTest.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkFilterOperatorTest.java      | 18 ++++++++++++++++++
 .../spark/operators/SparkFlatMapOperatorTest.java     | 18 ++++++++++++++++++
 .../SparkGlobalMaterializedGroupOperatorTest.java     | 18 ++++++++++++++++++
 .../operators/SparkGlobalReduceOperatorTest.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkJoinOperatorTest.java | 18 ++++++++++++++++++
 .../operators/SparkMapPartitionsOperatorTest.java     | 18 ++++++++++++++++++
 .../SparkMaterializedGroupByOperatorTest.java         | 18 ++++++++++++++++++
 .../spark/operators/SparkObjectFileSinkTest.java      | 18 ++++++++++++++++++
 .../spark/operators/SparkObjectFileSourceTest.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkOperatorTestBase.java | 18 ++++++++++++++++++
 .../SparkRandomPartitionSampleOperatorTest.java       | 18 ++++++++++++++++++
 .../spark/operators/SparkReduceByOperatorTest.java    | 18 ++++++++++++++++++
 .../SparkShufflePartitionSampleOperatorTest.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkSortOperatorTest.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSinkTest.java | 18 ++++++++++++++++++
 .../spark/operators/SparkUnionAllOperatorTest.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/test/ChannelFactory.java  | 18 ++++++++++++++++++
 wayang-platforms/wayang-sqlite3/pom.xml               | 11 +++++++++++
 .../main/java/org/apache/wayang/sqlite3/Sqlite3.java  | 18 ++++++++++++++++++
 .../wayang/sqlite3/channels/ChannelConversions.java   | 18 ++++++++++++++++++
 .../apache/wayang/sqlite3/mapping/FilterMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/sqlite3/mapping/Mappings.java   | 18 ++++++++++++++++++
 .../wayang/sqlite3/mapping/ProjectionMapping.java     | 18 ++++++++++++++++++
 .../sqlite3/operators/Sqlite3FilterOperator.java      | 18 ++++++++++++++++++
 .../sqlite3/operators/Sqlite3ProjectionOperator.java  | 18 ++++++++++++++++++
 .../wayang/sqlite3/operators/Sqlite3TableSource.java  | 18 ++++++++++++++++++
 .../wayang/sqlite3/platform/Sqlite3Platform.java      | 18 ++++++++++++++++++
 .../sqlite3/plugin/Sqlite3ConversionPlugin.java       | 18 ++++++++++++++++++
 .../apache/wayang/sqlite3/plugin/Sqlite3Plugin.java   | 18 ++++++++++++++++++
 wayang-profiler/pom.xml                               | 11 +++++++++++
 .../apache/wayang/profiler/data/DataGenerators.java   | 18 ++++++++++++++++++
 .../apache/wayang/profiler/hardware/DiskProfiler.java | 18 ++++++++++++++++++
 .../wayang/profiler/java/BinaryOperatorProfiler.java  | 18 ++++++++++++++++++
 .../profiler/java/JavaCollectionSourceProfiler.java   | 18 ++++++++++++++++++
 .../profiler/java/JavaTextFileSourceProfiler.java     | 18 ++++++++++++++++++
 .../apache/wayang/profiler/java/OperatorProfiler.java | 18 ++++++++++++++++++
 .../wayang/profiler/java/OperatorProfilers.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/java/Profiler.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/java/SinkProfiler.java | 18 ++++++++++++++++++
 .../apache/wayang/profiler/java/SourceProfiler.java   | 18 ++++++++++++++++++
 .../wayang/profiler/java/UnaryOperatorProfiler.java   | 18 ++++++++++++++++++
 .../wayang/profiler/log/DynamicEstimationContext.java | 18 ++++++++++++++++++
 .../wayang/profiler/log/DynamicLoadEstimator.java     | 18 ++++++++++++++++++
 .../profiler/log/DynamicLoadProfileEstimator.java     | 18 ++++++++++++++++++
 .../profiler/log/DynamicLoadProfileEstimators.java    | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/GeneticOptimizer.java  | 18 ++++++++++++++++++
 .../wayang/profiler/log/GeneticOptimizerApp.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/log/Individual.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/log/LogEvaluator.java  | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/OptimizationSpace.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/profiler/log/Variable.java | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/sampling/Battle.java   | 18 ++++++++++++++++++
 .../profiler/log/sampling/ReservoirSampler.java       | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/sampling/Sampler.java  | 18 ++++++++++++++++++
 .../profiler/log/sampling/TournamentSampler.java      | 18 ++++++++++++++++++
 .../wayang/profiler/spark/BinaryOperatorProfiler.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/profiler/spark/Main.java   | 18 ++++++++++++++++++
 .../wayang/profiler/spark/OperatorProfilers.java      | 18 ++++++++++++++++++
 .../apache/wayang/profiler/spark/SinkProfiler.java    | 18 ++++++++++++++++++
 .../profiler/spark/SparkCollectionSourceProfiler.java | 18 ++++++++++++++++++
 .../wayang/profiler/spark/SparkOperatorProfiler.java  | 18 ++++++++++++++++++
 .../wayang/profiler/spark/SparkSourceProfiler.java    | 18 ++++++++++++++++++
 .../profiler/spark/SparkTextFileSourceProfiler.java   | 18 ++++++++++++++++++
 .../profiler/spark/SparkUnaryOperatorProfiler.java    | 18 ++++++++++++++++++
 .../apache/wayang/profiler/util/ProfilingUtils.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/util/RrdAccessor.java  | 18 ++++++++++++++++++
 wayang-tests/pom.xml                                  | 11 +++++++++++
 .../org/apache/wayang/tests/FlinkIntegrationIT.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/FullIntegrationIT.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/GiraphIntegrationIT.java  | 18 ++++++++++++++++++
 .../apache/wayang/tests/GraphChiIntegrationIT.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/JavaIntegrationIT.java    | 18 ++++++++++++++++++
 .../apache/wayang/tests/PostgresIntegrationIT.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/tests/RegressionIT.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/SparkIntegrationIT.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/tests/WayangPlans.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/WayangPlansOperators.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/tests/WordCountIT.java     | 18 ++++++++++++++++++
 .../wayang/tests/platform/MyMadeUpPlatform.java       | 18 ++++++++++++++++++
 777 files changed, 13843 insertions(+), 1 deletion(-)
 create mode 100644 DISCLAIMER


[incubator-wayang] 04/16: Add header licence to files in wayang-basic

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 851429d41af67b4b8f8ec986051ef7860c7cd240
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 13:57:05 2021 -0300

    Add header licence to files in wayang-basic
---
 wayang-basic/pom.xml                                  | 11 +++++++++++
 .../java/org/apache/wayang/basic/WayangBasics.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/channels/FileChannel.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Record.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Tuple2.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/basic/data/Tuple5.java     | 18 ++++++++++++++++++
 .../wayang/basic/function/ProjectionDescriptor.java   | 18 ++++++++++++++++++
 .../wayang/basic/mapping/GlobalReduceMapping.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/mapping/Mappings.java     | 18 ++++++++++++++++++
 .../basic/mapping/MaterializedGroupByMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/PageRankMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/ReduceByMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/basic/mapping/RepeatMapping.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/CartesianOperator.java     | 18 ++++++++++++++++++
 .../wayang/basic/operators/CoGroupOperator.java       | 18 ++++++++++++++++++
 .../wayang/basic/operators/CollectionSource.java      | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/CountOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/DistinctOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/DoWhileOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/FilterOperator.java | 18 ++++++++++++++++++
 .../wayang/basic/operators/FlatMapOperator.java       | 18 ++++++++++++++++++
 .../operators/GlobalMaterializedGroupOperator.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/GlobalReduceOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/GroupByOperator.java       | 18 ++++++++++++++++++
 .../wayang/basic/operators/IntersectOperator.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/JoinOperator.java   | 18 ++++++++++++++++++
 .../wayang/basic/operators/LocalCallbackSink.java     | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/LoopOperator.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/MapOperator.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/MapPartitionsOperator.java | 18 ++++++++++++++++++
 .../basic/operators/MaterializedGroupByOperator.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/PageRankOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/ReduceByOperator.java      | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/ReduceOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/RepeatOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/SampleOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/SortOperator.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TableSource.java    | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TextFileSink.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/TextFileSource.java | 18 ++++++++++++++++++
 .../wayang/basic/operators/UnionAllOperator.java      | 18 ++++++++++++++++++
 .../wayang/basic/operators/ZipWithIdOperator.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/plugin/WayangBasic.java   | 18 ++++++++++++++++++
 .../apache/wayang/basic/plugin/WayangBasicGraph.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/types/RecordType.java     | 19 ++++++++++++++++++-
 .../basic/function/ProjectionDescriptorTest.java      | 18 ++++++++++++++++++
 .../wayang/basic/mapping/ReduceByMappingTest.java     | 18 ++++++++++++++++++
 .../operators/MaterializedGroupByOperatorTest.java    | 18 ++++++++++++++++++
 .../wayang/basic/operators/TextFileSourceTest.java    | 18 ++++++++++++++++++
 .../apache/wayang/basic/operators/test/TestSink.java  | 18 ++++++++++++++++++
 .../wayang/basic/operators/test/TestSource.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/basic/types/RecordTypeTest.java | 18 ++++++++++++++++++
 52 files changed, 929 insertions(+), 1 deletion(-)

diff --git a/wayang-basic/pom.xml b/wayang-basic/pom.xml
index 61c3e31..0f70d9d 100644
--- a/wayang-basic/pom.xml
+++ b/wayang-basic/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/WayangBasics.java b/wayang-basic/src/main/java/org/apache/wayang/basic/WayangBasics.java
index cb6e14e..d2dd0e7 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/WayangBasics.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/WayangBasics.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic;
 
 import org.apache.wayang.basic.plugin.WayangBasic;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/channels/FileChannel.java b/wayang-basic/src/main/java/org/apache/wayang/basic/channels/FileChannel.java
index 67d5850..9a56afb 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/channels/FileChannel.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/channels/FileChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.channels;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Record.java b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Record.java
index 0c4fd87..d11506c 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Record.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Record.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.data;
 
 import org.apache.wayang.core.util.Copyable;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple2.java b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple2.java
index af2027e..b7166ed 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple2.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple2.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.data;
 
 import java.io.Serializable;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple5.java b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple5.java
index fd89eac..dcb7e2a 100755
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple5.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/data/Tuple5.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.data;
 
 import java.io.Serializable;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/function/ProjectionDescriptor.java b/wayang-basic/src/main/java/org/apache/wayang/basic/function/ProjectionDescriptor.java
index b3e9dfb..5db00d7 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/function/ProjectionDescriptor.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/function/ProjectionDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.function;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/GlobalReduceMapping.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/GlobalReduceMapping.java
index f605eb0..3fe03d6 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/GlobalReduceMapping.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/GlobalReduceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.basic.operators.GlobalReduceOperator;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/Mappings.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/Mappings.java
index 1a22a46..38bf55b 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/Mappings.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/MaterializedGroupByMapping.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/MaterializedGroupByMapping.java
index d9eea43..62c49c3 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/MaterializedGroupByMapping.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/MaterializedGroupByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.basic.operators.GroupByOperator;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/PageRankMapping.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/PageRankMapping.java
index 39a1fbf..9491b4d 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/PageRankMapping.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/ReduceByMapping.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/ReduceByMapping.java
index 83fbd0b..f9b9e1a 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/ReduceByMapping.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/ReduceByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.basic.operators.GroupByOperator;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/RepeatMapping.java b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/RepeatMapping.java
index 91c64dc..d92edf2 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/RepeatMapping.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/mapping/RepeatMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CartesianOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CartesianOperator.java
index c94dd9d..4fde9fc 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CartesianOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CartesianOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CoGroupOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CoGroupOperator.java
index 54ed359..22676e9 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CoGroupOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CoGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CollectionSource.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CollectionSource.java
index 0a7f8b6..0150263 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CollectionSource.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CollectionSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CountOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CountOperator.java
index 3bbc535..0740575 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CountOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/CountOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DistinctOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DistinctOperator.java
index cc936a5..bf1e2d4 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DistinctOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DistinctOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DoWhileOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DoWhileOperator.java
index 3a73da2..8966f01 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DoWhileOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/DoWhileOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FilterOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FilterOperator.java
index 4fbd993..767ff69 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FilterOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FlatMapOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FlatMapOperator.java
index 22b14e8..e2d4406 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FlatMapOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/FlatMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalMaterializedGroupOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalMaterializedGroupOperator.java
index f629e8d..3ddb8b5 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalMaterializedGroupOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalMaterializedGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalReduceOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalReduceOperator.java
index 621ff54..3c03e1c 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalReduceOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GlobalReduceOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GroupByOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GroupByOperator.java
index f0253f4..70d9405 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GroupByOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/GroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.function.FunctionDescriptor;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/IntersectOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/IntersectOperator.java
index 9210d80..d082695 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/IntersectOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/IntersectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/JoinOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/JoinOperator.java
index e12b645..1d4d1f3 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/JoinOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/JoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LocalCallbackSink.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LocalCallbackSink.java
index 17428e9..d88e963 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LocalCallbackSink.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LocalCallbackSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LoopOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LoopOperator.java
index 8c44ff2..e83022c 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LoopOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/LoopOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapOperator.java
index 95eb850..13c25a1 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapPartitionsOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapPartitionsOperator.java
index b73c96e..976845e 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapPartitionsOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MapPartitionsOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MaterializedGroupByOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MaterializedGroupByOperator.java
index 3aa90b5..5a1e322 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MaterializedGroupByOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/MaterializedGroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/PageRankOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/PageRankOperator.java
index 0df0838..49a9cc6 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/PageRankOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/PageRankOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceByOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceByOperator.java
index 91b701b..dd078d0 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceByOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceOperator.java
index ad0e487..8d93f0b 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ReduceOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/RepeatOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/RepeatOperator.java
index 79e7609..a2c97b7 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/RepeatOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/RepeatOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SampleOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SampleOperator.java
index 4685977..a8013d0 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SampleOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SortOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SortOperator.java
index 6c22b49..3436b98 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SortOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/SortOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TableSource.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TableSource.java
index c740527..6c1a057 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TableSource.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TableSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSink.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSink.java
index d35cb85..970a11f 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSink.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.wayang.core.function.TransformationDescriptor;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSource.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSource.java
index 61d1e8f..1fc7642 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSource.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/TextFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import de.hpi.isg.profiledb.store.model.TimeMeasurement;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/UnionAllOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/UnionAllOperator.java
index d8fa7f2..449ee9e 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/UnionAllOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/UnionAllOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ZipWithIdOperator.java b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ZipWithIdOperator.java
index b43864c..001b010 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ZipWithIdOperator.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/operators/ZipWithIdOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasic.java b/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasic.java
index cc6e51b..e580af7 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasic.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasic.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.plugin;
 
 import org.apache.wayang.basic.mapping.Mappings;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasicGraph.java b/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasicGraph.java
index 2418bb1..87c7045 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasicGraph.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/plugin/WayangBasicGraph.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.plugin;
 
 import org.apache.wayang.basic.mapping.Mappings;
diff --git a/wayang-basic/src/main/java/org/apache/wayang/basic/types/RecordType.java b/wayang-basic/src/main/java/org/apache/wayang/basic/types/RecordType.java
index bd55f54..7988e99 100644
--- a/wayang-basic/src/main/java/org/apache/wayang/basic/types/RecordType.java
+++ b/wayang-basic/src/main/java/org/apache/wayang/basic/types/RecordType.java
@@ -1,5 +1,22 @@
-package org.apache.wayang.basic.types;
+/*
+ * 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 org.apache.wayang.basic.types;
 
 import org.apache.wayang.basic.data.Record;
 import org.apache.wayang.core.types.BasicDataUnitType;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/function/ProjectionDescriptorTest.java b/wayang-basic/src/test/java/org/apache/wayang/basic/function/ProjectionDescriptorTest.java
index 8998a63..4532264 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/function/ProjectionDescriptorTest.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/function/ProjectionDescriptorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.function;
 
 import org.junit.Assert;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/mapping/ReduceByMappingTest.java b/wayang-basic/src/test/java/org/apache/wayang/basic/mapping/ReduceByMappingTest.java
index bb8ee80..20d5a63 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/mapping/ReduceByMappingTest.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/mapping/ReduceByMappingTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.mapping;
 
 import org.junit.Assert;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/MaterializedGroupByOperatorTest.java b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/MaterializedGroupByOperatorTest.java
index cea0670..d5f21a7 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/MaterializedGroupByOperatorTest.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/MaterializedGroupByOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import org.junit.Test;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/TextFileSourceTest.java b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/TextFileSourceTest.java
index 3b8351e..48b9678 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/TextFileSourceTest.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/TextFileSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators;
 
 import de.hpi.isg.profiledb.instrumentation.StopWatch;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSink.java b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSink.java
index d08f08d..afd698e 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSink.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators.test;
 
 import org.apache.wayang.core.plan.wayangplan.UnarySink;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSource.java b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSource.java
index 60ae059..68ff5af 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSource.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/operators/test/TestSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.operators.test;
 
 import org.apache.wayang.core.plan.wayangplan.UnarySource;
diff --git a/wayang-basic/src/test/java/org/apache/wayang/basic/types/RecordTypeTest.java b/wayang-basic/src/test/java/org/apache/wayang/basic/types/RecordTypeTest.java
index 6e7f57e..9d8b472 100644
--- a/wayang-basic/src/test/java/org/apache/wayang/basic/types/RecordTypeTest.java
+++ b/wayang-basic/src/test/java/org/apache/wayang/basic/types/RecordTypeTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.basic.types;
 
 import org.junit.Assert;


[incubator-wayang] 16/16: Add header licence to files in wayang-test

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 086f6a049a33d3fcdb30f38c3d93f358cfe50b6a
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:26:59 2021 -0300

    Add header licence to files in wayang-test
---
 pom.xml                                                | 11 +++++++++++
 wayang-tests/pom.xml                                   | 11 +++++++++++
 .../org/apache/wayang/tests/FlinkIntegrationIT.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/FullIntegrationIT.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/GiraphIntegrationIT.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/GraphChiIntegrationIT.java | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/JavaIntegrationIT.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/PostgresIntegrationIT.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/tests/RegressionIT.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/SparkIntegrationIT.java    | 18 ++++++++++++++++++
 .../test/java/org/apache/wayang/tests/WayangPlans.java | 18 ++++++++++++++++++
 .../org/apache/wayang/tests/WayangPlansOperators.java  | 18 ++++++++++++++++++
 .../test/java/org/apache/wayang/tests/WordCountIT.java | 18 ++++++++++++++++++
 .../apache/wayang/tests/platform/MyMadeUpPlatform.java | 18 ++++++++++++++++++
 14 files changed, 238 insertions(+)

diff --git a/pom.xml b/pom.xml
index c51482a..cce4739 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/wayang-tests/pom.xml b/wayang-tests/pom.xml
index 0da801b..a3758aa 100644
--- a/wayang-tests/pom.xml
+++ b/wayang-tests/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/FlinkIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/FlinkIntegrationIT.java
index bc4abdb..6698750 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/FlinkIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/FlinkIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/FullIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/FullIntegrationIT.java
index 114d9e0..51cf036 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/FullIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/FullIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/GiraphIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/GiraphIntegrationIT.java
index 3b5db6c..54b2658 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/GiraphIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/GiraphIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/GraphChiIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/GraphChiIntegrationIT.java
index 9edaba7..997f44a 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/GraphChiIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/GraphChiIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/JavaIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/JavaIntegrationIT.java
index c0ee652..deafb00 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/JavaIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/JavaIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/PostgresIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/PostgresIntegrationIT.java
index adb2ec5..721f27b 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/PostgresIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/PostgresIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.AfterClass;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/RegressionIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/RegressionIT.java
index c18d110..59b48cd 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/RegressionIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/RegressionIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/SparkIntegrationIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/SparkIntegrationIT.java
index 8c8bd8e..7323f8d 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/SparkIntegrationIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/SparkIntegrationIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlans.java b/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlans.java
index 102220a..3062afb 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlans.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlans.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.apache.wayang.api.DataQuantaBuilder;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlansOperators.java b/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlansOperators.java
index 78bf29b..1dc5179 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlansOperators.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/WayangPlansOperators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/WordCountIT.java b/wayang-tests/src/test/java/org/apache/wayang/tests/WordCountIT.java
index 2983122..0175ae5 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/WordCountIT.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/WordCountIT.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests;
 
 import org.junit.Assert;
diff --git a/wayang-tests/src/test/java/org/apache/wayang/tests/platform/MyMadeUpPlatform.java b/wayang-tests/src/test/java/org/apache/wayang/tests/platform/MyMadeUpPlatform.java
index 12cf539..bc93d30 100644
--- a/wayang-tests/src/test/java/org/apache/wayang/tests/platform/MyMadeUpPlatform.java
+++ b/wayang-tests/src/test/java/org/apache/wayang/tests/platform/MyMadeUpPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.tests.platform;
 
 import org.apache.wayang.core.api.Configuration;


[incubator-wayang] 13/16: Add header licence to files in wayang-spark

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit c5a0edbc5cb13e92d2339dc83dc1ac56465c6162
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:23:55 2021 -0300

    Add header licence to files in wayang-spark
---
 wayang-platforms/wayang-spark/pom.xml                  | 11 +++++++++++
 .../src/main/java/org/apache/wayang/spark/Spark.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/channels/BroadcastChannel.java | 18 ++++++++++++++++++
 .../wayang/spark/channels/ChannelConversions.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/channels/FileChannels.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/channels/RddChannel.java   | 18 ++++++++++++++++++
 .../wayang/spark/compiler/BinaryOperatorAdapter.java   | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedBinaryOperatorAdapter.java  | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedFlatMapFunctionAdapter.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/compiler/ExtendedFunction.java | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedMapFunctionAdapter.java     | 18 ++++++++++++++++++
 .../compiler/ExtendedMapPartitionsFunctionAdapter.java | 18 ++++++++++++++++++
 .../spark/compiler/ExtendedPredicateAdapater.java      | 18 ++++++++++++++++++
 .../wayang/spark/compiler/FlatMapFunctionAdapter.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/compiler/FunctionCompiler.java | 18 ++++++++++++++++++
 .../wayang/spark/compiler/MapFunctionAdapter.java      | 18 ++++++++++++++++++
 .../spark/compiler/MapPartitionsFunctionAdapter.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/compiler/PredicateAdapter.java | 18 ++++++++++++++++++
 .../wayang/spark/execution/SparkContextReference.java  | 18 ++++++++++++++++++
 .../wayang/spark/execution/SparkExecutionContext.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/execution/SparkExecutor.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/CartesianMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/CoGroupMapping.java    | 18 ++++++++++++++++++
 .../wayang/spark/mapping/CollectionSourceMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/CountMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/DistinctMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/DoWhileMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/FilterMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/FlatMapMapping.java    | 18 ++++++++++++++++++
 .../spark/mapping/GlobalMaterializedGroupMapping.java  | 18 ++++++++++++++++++
 .../wayang/spark/mapping/GlobalReduceMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/IntersectMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/JoinMapping.java   | 18 ++++++++++++++++++
 .../wayang/spark/mapping/LocalCallbackSinkMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/LoopMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/MapMapping.java    | 18 ++++++++++++++++++
 .../wayang/spark/mapping/MapPartitionsMapping.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/spark/mapping/Mappings.java | 18 ++++++++++++++++++
 .../spark/mapping/MaterializedGroupByMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/ReduceByMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/RepeatMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/SampleMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/mapping/SortMapping.java   | 18 ++++++++++++++++++
 .../wayang/spark/mapping/TextFileSinkMapping.java      | 18 ++++++++++++++++++
 .../wayang/spark/mapping/TextFileSourceMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/UnionAllMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/spark/mapping/ZipWithIdMapping.java  | 18 ++++++++++++++++++
 .../wayang/spark/mapping/graph/PageRankMapping.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkBernoulliSampleOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkBroadcastOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCacheOperator.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCartesianOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCoGroupOperator.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCollectOperator.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCollectionSource.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCountOperator.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkDistinctOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkDoWhileOperator.java   | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkExecutionOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkFilterOperator.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkFlatMapOperator.java   | 18 ++++++++++++++++++
 .../SparkGlobalMaterializedGroupOperator.java          | 18 ++++++++++++++++++
 .../spark/operators/SparkGlobalReduceOperator.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkIntersectOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkJoinOperator.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkLocalCallbackSink.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkLoopOperator.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkMapOperator.java       | 18 ++++++++++++++++++
 .../spark/operators/SparkMapPartitionsOperator.java    | 18 ++++++++++++++++++
 .../operators/SparkMaterializedGroupByOperator.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkObjectFileSink.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkObjectFileSource.java  | 18 ++++++++++++++++++
 .../operators/SparkRandomPartitionSampleOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkReduceByOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkRepeatOperator.java    | 18 ++++++++++++++++++
 .../operators/SparkShufflePartitionSampleOperator.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkSortOperator.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSink.java      | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSource.java    | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTsvFileSink.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTsvFileSource.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkUnionAllOperator.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkZipWithIdOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/spark/platform/SparkPlatform.java    | 18 ++++++++++++++++++
 .../apache/wayang/spark/plugin/SparkBasicPlugin.java   | 18 ++++++++++++++++++
 .../wayang/spark/plugin/SparkConversionPlugin.java     | 18 ++++++++++++++++++
 .../apache/wayang/spark/plugin/SparkGraphPlugin.java   | 18 ++++++++++++++++++
 .../spark/operators/graph/SparkPageRankOperator.scala  | 18 ++++++++++++++++++
 .../operators/SparkBernoulliSampleOperatorTest.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkCartesianOperatorTest.java    | 18 ++++++++++++++++++
 .../spark/operators/SparkCoGroupOperatorTest.java      | 18 ++++++++++++++++++
 .../spark/operators/SparkCollectionSourceTest.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkCountOperatorTest.java | 18 ++++++++++++++++++
 .../spark/operators/SparkDistinctOperatorTest.java     | 18 ++++++++++++++++++
 .../spark/operators/SparkFilterOperatorTest.java       | 18 ++++++++++++++++++
 .../spark/operators/SparkFlatMapOperatorTest.java      | 18 ++++++++++++++++++
 .../SparkGlobalMaterializedGroupOperatorTest.java      | 18 ++++++++++++++++++
 .../spark/operators/SparkGlobalReduceOperatorTest.java | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkJoinOperatorTest.java  | 18 ++++++++++++++++++
 .../operators/SparkMapPartitionsOperatorTest.java      | 18 ++++++++++++++++++
 .../SparkMaterializedGroupByOperatorTest.java          | 18 ++++++++++++++++++
 .../spark/operators/SparkObjectFileSinkTest.java       | 18 ++++++++++++++++++
 .../spark/operators/SparkObjectFileSourceTest.java     | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkOperatorTestBase.java  | 18 ++++++++++++++++++
 .../SparkRandomPartitionSampleOperatorTest.java        | 18 ++++++++++++++++++
 .../spark/operators/SparkReduceByOperatorTest.java     | 18 ++++++++++++++++++
 .../SparkShufflePartitionSampleOperatorTest.java       | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkSortOperatorTest.java  | 18 ++++++++++++++++++
 .../wayang/spark/operators/SparkTextFileSinkTest.java  | 18 ++++++++++++++++++
 .../spark/operators/SparkUnionAllOperatorTest.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/spark/test/ChannelFactory.java   | 18 ++++++++++++++++++
 111 files changed, 1991 insertions(+)

diff --git a/wayang-platforms/wayang-spark/pom.xml b/wayang-platforms/wayang-spark/pom.xml
index 5988156..a64eb6f 100644
--- a/wayang-platforms/wayang-spark/pom.xml
+++ b/wayang-platforms/wayang-spark/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/Spark.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/Spark.java
index 7c15e05..3bd3d91 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/Spark.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/Spark.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark;
 
 import org.apache.wayang.spark.platform.SparkPlatform;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/BroadcastChannel.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/BroadcastChannel.java
index 9bcfa1e..6a425c5 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/BroadcastChannel.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/BroadcastChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.channels;
 
 import org.apache.spark.broadcast.Broadcast;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/ChannelConversions.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/ChannelConversions.java
index 84c3da2..9f8fca1 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.channels;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/FileChannels.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/FileChannels.java
index f0616ec..ee70538 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/FileChannels.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/FileChannels.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.channels;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/RddChannel.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/RddChannel.java
index 670c732..36f1877 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/RddChannel.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/channels/RddChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.channels;
 
 import org.apache.spark.Accumulator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/BinaryOperatorAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/BinaryOperatorAdapter.java
index 02fea5a..5ffffda 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/BinaryOperatorAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/BinaryOperatorAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function2;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedBinaryOperatorAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedBinaryOperatorAdapter.java
index 442aad9..627ede6 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedBinaryOperatorAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedBinaryOperatorAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function2;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFlatMapFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFlatMapFunctionAdapter.java
index 79fc19a..7040f16 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFlatMapFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFlatMapFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.FlatMapFunction;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFunction.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFunction.java
index f01b91d..1363c9f 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFunction.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapFunctionAdapter.java
index 7932235..f3637b4 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapPartitionsFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapPartitionsFunctionAdapter.java
index 10417b2..18871ed 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapPartitionsFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedMapPartitionsFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.FlatMapFunction;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedPredicateAdapater.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedPredicateAdapater.java
index 2bb4e4a..6e1c5f1 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedPredicateAdapater.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/ExtendedPredicateAdapater.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FlatMapFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FlatMapFunctionAdapter.java
index 45f3354..9216fcc 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FlatMapFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FlatMapFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.FlatMapFunction;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FunctionCompiler.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FunctionCompiler.java
index 38f1e4a..2ced813 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FunctionCompiler.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/FunctionCompiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapFunctionAdapter.java
index 1e126d9..9933cb5 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapPartitionsFunctionAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapPartitionsFunctionAdapter.java
index 8afe14f..3fb7683 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapPartitionsFunctionAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/MapPartitionsFunctionAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.FlatMapFunction;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/PredicateAdapter.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/PredicateAdapter.java
index a19c155..931d47e 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/PredicateAdapter.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/compiler/PredicateAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.compiler;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkContextReference.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkContextReference.java
index e3085c5..da05589 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkContextReference.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkContextReference.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.execution;
 
 import org.apache.spark.api.java.JavaSparkContext;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutionContext.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutionContext.java
index cc07f22..ab11e05 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutionContext.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutionContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.execution;
 
 import org.apache.spark.broadcast.Broadcast;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutor.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutor.java
index 8ff1e0c..9aab425 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutor.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/execution/SparkExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.execution;
 
 import org.apache.spark.api.java.JavaSparkContext;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CartesianMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CartesianMapping.java
index fecb861..203de34 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CartesianMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CartesianMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CartesianOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CoGroupMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CoGroupMapping.java
index 28ade2b..2eabfb4 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CoGroupMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CoGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CoGroupOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CollectionSourceMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CollectionSourceMapping.java
index a3b436e..b648e81 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CollectionSourceMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CollectionSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CountMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CountMapping.java
index c09b7e2..2ae19e9 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CountMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/CountMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CountOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DistinctMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DistinctMapping.java
index c6e3843..aa8773d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DistinctMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DistinctMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.DistinctOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DoWhileMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DoWhileMapping.java
index ed8153e..924c814 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DoWhileMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/DoWhileMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.DoWhileOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FilterMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FilterMapping.java
index 11193ee..eeac994 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FilterMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FilterMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.FilterOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FlatMapMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FlatMapMapping.java
index 97dd2f9..1b88b61 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FlatMapMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/FlatMapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.FlatMapOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalMaterializedGroupMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalMaterializedGroupMapping.java
index 6365d2c..3c79d70 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalMaterializedGroupMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalMaterializedGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalReduceMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalReduceMapping.java
index 093db8f..30ea8ba 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalReduceMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/GlobalReduceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.GlobalReduceOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/IntersectMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/IntersectMapping.java
index b8f3e74..8f5e4da 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/IntersectMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/IntersectMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.IntersectOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/JoinMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/JoinMapping.java
index f92e42b..a2bbc94 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/JoinMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/JoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.JoinOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LocalCallbackSinkMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LocalCallbackSinkMapping.java
index cbb9d60..301246b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LocalCallbackSinkMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LocalCallbackSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.LocalCallbackSink;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LoopMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LoopMapping.java
index 3aa6ac0..d4f3d09 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LoopMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/LoopMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.LoopOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapMapping.java
index 5b40f15..6d88bef 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.MapOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapPartitionsMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapPartitionsMapping.java
index f9dedb9..fd33b52 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapPartitionsMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MapPartitionsMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.MapPartitionsOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/Mappings.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/Mappings.java
index b96c009..70ec802 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/Mappings.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MaterializedGroupByMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MaterializedGroupByMapping.java
index 8229bcb..beca291 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MaterializedGroupByMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/MaterializedGroupByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.MaterializedGroupByOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ReduceByMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ReduceByMapping.java
index e7a494c..6279e4d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ReduceByMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ReduceByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.ReduceByOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/RepeatMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/RepeatMapping.java
index b7f6428..d36587e 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/RepeatMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/RepeatMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.RepeatOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SampleMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SampleMapping.java
index 21b1df6..fb2d7a1 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SampleMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SampleMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.SampleOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SortMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SortMapping.java
index 7e8cd53..7938c09 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SortMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/SortMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.SortOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSinkMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSinkMapping.java
index f511de4..d43a2b4 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSinkMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSourceMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSourceMapping.java
index 9c1e6e6..09063e1 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSourceMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/TextFileSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/UnionAllMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/UnionAllMapping.java
index 01912cd..e5b5a44 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/UnionAllMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/UnionAllMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.UnionAllOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ZipWithIdMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ZipWithIdMapping.java
index 307adad..6ac4f54 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ZipWithIdMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/ZipWithIdMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping;
 
 import org.apache.wayang.basic.operators.ZipWithIdOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/graph/PageRankMapping.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/graph/PageRankMapping.java
index 0bda812..a9bc1bb 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/graph/PageRankMapping.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/mapping/graph/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.mapping.graph;
 
 import org.apache.wayang.basic.operators.PageRankOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperator.java
index 76a7fac..be041ae 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBroadcastOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBroadcastOperator.java
index 1894e62..ce90108 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBroadcastOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkBroadcastOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.broadcast.Broadcast;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCacheOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCacheOperator.java
index 46f5fc1..cbf62e2 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCacheOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCacheOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCartesianOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCartesianOperator.java
index 219d9c1..25d8b5b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCartesianOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCartesianOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCoGroupOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCoGroupOperator.java
index 0c91a53..162546b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCoGroupOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCoGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectOperator.java
index 13dcba3..c237eae 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectionSource.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectionSource.java
index 6a2f95d..5258733 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectionSource.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCollectionSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCountOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCountOperator.java
index 408c865..6356b50 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCountOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkCountOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.wayang.basic.operators.CountOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDistinctOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDistinctOperator.java
index 8fb4577..b7a870c 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDistinctOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDistinctOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDoWhileOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDoWhileOperator.java
index ed99560..498daed 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDoWhileOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkDoWhileOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkExecutionOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkExecutionOperator.java
index 8b1a4a1..80fb5ab 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkExecutionOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFilterOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFilterOperator.java
index ce2e73c..737061e 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFilterOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFlatMapOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFlatMapOperator.java
index 35081b6..2a1a28d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFlatMapOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkFlatMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperator.java
index 3cde9e3..75c3620 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperator.java
index 46faec5..cf87b5a 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkIntersectOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkIntersectOperator.java
index 600f0dd..931fc1b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkIntersectOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkIntersectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkJoinOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkJoinOperator.java
index 2bda893..cbba24b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkJoinOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLocalCallbackSink.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLocalCallbackSink.java
index 24463b1..c909d29 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLocalCallbackSink.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLocalCallbackSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLoopOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLoopOperator.java
index 66debdf..b72b3a7 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLoopOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkLoopOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapOperator.java
index ae7aa46..25e6bda 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperator.java
index c7bcc88..f13403d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperator.java
index 1366ec1..9c83160 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSink.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSink.java
index 57ac8af..99c0c64 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSink.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSource.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSource.java
index 28845f8..7788ec8 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSource.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkObjectFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperator.java
index 04aafb4..8333a17 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.SparkContext;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkReduceByOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkReduceByOperator.java
index da2efda..8bf3f33 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkReduceByOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkReduceByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRepeatOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRepeatOperator.java
index c4f3a16..916f1c0 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRepeatOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkRepeatOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.wayang.basic.operators.RepeatOperator;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperator.java
index 7383041..ca1c36b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.SparkContext;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkSortOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkSortOperator.java
index e9e2471..8605541 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkSortOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkSortOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSink.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSink.java
index 0c395fc..c20bb01 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSink.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSource.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSource.java
index b09df4a..acf9f1d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSource.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTextFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSink.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSink.java
index c5a7fd9..076fd1b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSink.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSource.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSource.java
index 8728bc1..e611798 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSource.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkTsvFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkUnionAllOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkUnionAllOperator.java
index adc19ae..7ca4a0d 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkUnionAllOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkUnionAllOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkZipWithIdOperator.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkZipWithIdOperator.java
index e6d8758..a5a3f22 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkZipWithIdOperator.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/operators/SparkZipWithIdOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/platform/SparkPlatform.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/platform/SparkPlatform.java
index 08669a7..d474607 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/platform/SparkPlatform.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/platform/SparkPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.platform;
 
 import org.apache.spark.SparkConf;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkBasicPlugin.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkBasicPlugin.java
index febff6f..f4dfae1 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkBasicPlugin.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkBasicPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkConversionPlugin.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkConversionPlugin.java
index b024b8e..f6c4c51 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkConversionPlugin.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkConversionPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkGraphPlugin.java b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkGraphPlugin.java
index 7200b6d..2b6514b 100644
--- a/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkGraphPlugin.java
+++ b/wayang-platforms/wayang-spark/src/main/java/org/apache/wayang/spark/plugin/SparkGraphPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-spark/src/main/scala/org/apache/wayang/spark/operators/graph/SparkPageRankOperator.scala b/wayang-platforms/wayang-spark/src/main/scala/org/apache/wayang/spark/operators/graph/SparkPageRankOperator.scala
index c4ef718..b5cb29e 100644
--- a/wayang-platforms/wayang-spark/src/main/scala/org/apache/wayang/spark/operators/graph/SparkPageRankOperator.scala
+++ b/wayang-platforms/wayang-spark/src/main/scala/org/apache/wayang/spark/operators/graph/SparkPageRankOperator.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators.graph
 
 import java.lang.{Long => JavaLong}
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperatorTest.java
index 00b5a58..4de83a0 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkBernoulliSampleOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCartesianOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCartesianOperatorTest.java
index e66de05..9d6c4b2 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCartesianOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCartesianOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCoGroupOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCoGroupOperatorTest.java
index 055b78a..5ff68c4 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCoGroupOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCoGroupOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCollectionSourceTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCollectionSourceTest.java
index 2914772..52205cb 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCollectionSourceTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCollectionSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCountOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCountOperatorTest.java
index 644ef3a..9d1317c 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCountOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkCountOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkDistinctOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkDistinctOperatorTest.java
index 346a671..157490a 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkDistinctOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkDistinctOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFilterOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFilterOperatorTest.java
index a9b7d26..8aacc54 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFilterOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFilterOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFlatMapOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFlatMapOperatorTest.java
index 3527f00..246a24f 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFlatMapOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkFlatMapOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperatorTest.java
index 00e56ac..4cfcbbd 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalMaterializedGroupOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperatorTest.java
index 85867ff..9f0e72e 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkGlobalReduceOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkJoinOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkJoinOperatorTest.java
index dff3785..ab65150 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkJoinOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkJoinOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperatorTest.java
index 210f47d..dee490c 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMapPartitionsOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperatorTest.java
index 81096c7..8886cb7 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkMaterializedGroupByOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSinkTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSinkTest.java
index a595c84..717360a 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSinkTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSinkTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSourceTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSourceTest.java
index 8b631b7..30d1282 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSourceTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkObjectFileSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkOperatorTestBase.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkOperatorTestBase.java
index 1a39603..a1ae810 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkOperatorTestBase.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkOperatorTestBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.apache.spark.api.java.JavaSparkContext;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperatorTest.java
index b67a8a3..8e4da05 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkRandomPartitionSampleOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkReduceByOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkReduceByOperatorTest.java
index a7b153a..ff97e7d 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkReduceByOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkReduceByOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperatorTest.java
index 88b6e9c..ee0ec52 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkShufflePartitionSampleOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkSortOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkSortOperatorTest.java
index cf2397e..6109fe7 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkSortOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkSortOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkTextFileSinkTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkTextFileSinkTest.java
index c6a86fd..57523ba 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkTextFileSinkTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkTextFileSinkTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Test;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkUnionAllOperatorTest.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkUnionAllOperatorTest.java
index aea8db3..d94059b 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkUnionAllOperatorTest.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/operators/SparkUnionAllOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/test/ChannelFactory.java b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/test/ChannelFactory.java
index 7975fee..e83c44f 100644
--- a/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/test/ChannelFactory.java
+++ b/wayang-platforms/wayang-spark/src/test/java/org/apache/wayang/spark/test/ChannelFactory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.spark.test;
 
 import org.junit.Before;


[incubator-wayang] 03/16: Add header licence to files in wayang-distro

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit cb96db9707445e93c871e3402e0dd9665b4fee20
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 13:50:53 2021 -0300

    Add header licence to files in wayang-distro
---
 wayang-distro/pom.xml                 | 11 +++++++++++
 wayang-distro/src/assembly/distro.xml | 11 +++++++++++
 2 files changed, 22 insertions(+)

diff --git a/wayang-distro/pom.xml b/wayang-distro/pom.xml
index 3edf85d..5b3e859 100644
--- a/wayang-distro/pom.xml
+++ b/wayang-distro/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
diff --git a/wayang-distro/src/assembly/distro.xml b/wayang-distro/src/assembly/distro.xml
index 45e8e75..e95aa04 100644
--- a/wayang-distro/src/assembly/distro.xml
+++ b/wayang-distro/src/assembly/distro.xml
@@ -1,3 +1,14 @@
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.3"
           xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
           xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.3 http://maven.apache.org/xsd/assembly-1.1.3.xsd">


[incubator-wayang] 11/16: Add header licence to files in wayang-postgres

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 423cd4bd5d5983adacfd4c64b2e792554f978042
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:22:05 2021 -0300

    Add header licence to files in wayang-postgres
---
 wayang-platforms/wayang-postgres/pom.xml               | 11 +++++++++++
 .../main/java/org/apache/wayang/postgres/Postgres.java | 18 ++++++++++++++++++
 .../wayang/postgres/channels/ChannelConversions.java   | 18 ++++++++++++++++++
 .../apache/wayang/postgres/mapping/FilterMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/postgres/mapping/Mappings.java   | 18 ++++++++++++++++++
 .../wayang/postgres/mapping/ProjectionMapping.java     | 18 ++++++++++++++++++
 .../postgres/operators/PostgresExecutionOperator.java  | 18 ++++++++++++++++++
 .../postgres/operators/PostgresFilterOperator.java     | 18 ++++++++++++++++++
 .../postgres/operators/PostgresProjectionOperator.java | 18 ++++++++++++++++++
 .../wayang/postgres/operators/PostgresTableSource.java | 18 ++++++++++++++++++
 .../wayang/postgres/platform/PostgresPlatform.java     | 18 ++++++++++++++++++
 .../postgres/plugin/PostgresConversionsPlugin.java     | 18 ++++++++++++++++++
 .../apache/wayang/postgres/plugin/PostgresPlugin.java  | 18 ++++++++++++++++++
 13 files changed, 227 insertions(+)

diff --git a/wayang-platforms/wayang-postgres/pom.xml b/wayang-platforms/wayang-postgres/pom.xml
index df5c942..a6b25bf 100644
--- a/wayang-platforms/wayang-postgres/pom.xml
+++ b/wayang-platforms/wayang-postgres/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/Postgres.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/Postgres.java
index c45d00c..7869e5b 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/Postgres.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/Postgres.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres;
 
 
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/channels/ChannelConversions.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/channels/ChannelConversions.java
index 6f47859..8134b6c 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.channels;
 
 import org.apache.wayang.core.optimizer.channels.ChannelConversion;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/FilterMapping.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/FilterMapping.java
index d720572..7a38724 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/FilterMapping.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/FilterMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.mapping;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/Mappings.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/Mappings.java
index e208eba..56e8ff6 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/Mappings.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/ProjectionMapping.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/ProjectionMapping.java
index 64002dc..0fae1a8 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/ProjectionMapping.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/mapping/ProjectionMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.mapping;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresExecutionOperator.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresExecutionOperator.java
index f33f68b..da90298 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresExecutionOperator.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.operators;
 
 import org.apache.wayang.jdbc.operators.JdbcExecutionOperator;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresFilterOperator.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresFilterOperator.java
index 89e470e..20bd3b0 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresFilterOperator.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresProjectionOperator.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresProjectionOperator.java
index 20e3f9d..0a7d72a 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresProjectionOperator.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresProjectionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresTableSource.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresTableSource.java
index d354b4c..15e8332 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresTableSource.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/operators/PostgresTableSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.operators;
 
 import org.apache.wayang.basic.operators.TableSource;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/platform/PostgresPlatform.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/platform/PostgresPlatform.java
index 9273f93..574acb9 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/platform/PostgresPlatform.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/platform/PostgresPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.platform;
 
 import org.apache.wayang.core.platform.Platform;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresConversionsPlugin.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresConversionsPlugin.java
index fa8272a..3c169a6 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresConversionsPlugin.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresConversionsPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresPlugin.java b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresPlugin.java
index 9dabba4..edc5c3a 100644
--- a/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresPlugin.java
+++ b/wayang-platforms/wayang-postgres/src/main/java/org/apache/wayang/postgres/plugin/PostgresPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.postgres.plugin;
 
 import org.apache.wayang.core.api.Configuration;


[incubator-wayang] 14/16: Add header licence to files in wayang-sqlite3

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 260e6d2695056b52e25f840c8333362c645387f1
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:25:35 2021 -0300

    Add header licence to files in wayang-sqlite3
---
 wayang-platforms/wayang-sqlite3/pom.xml                | 11 +++++++++++
 .../main/java/org/apache/wayang/sqlite3/Sqlite3.java   | 18 ++++++++++++++++++
 .../wayang/sqlite3/channels/ChannelConversions.java    | 18 ++++++++++++++++++
 .../apache/wayang/sqlite3/mapping/FilterMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/sqlite3/mapping/Mappings.java    | 18 ++++++++++++++++++
 .../wayang/sqlite3/mapping/ProjectionMapping.java      | 18 ++++++++++++++++++
 .../sqlite3/operators/Sqlite3FilterOperator.java       | 18 ++++++++++++++++++
 .../sqlite3/operators/Sqlite3ProjectionOperator.java   | 18 ++++++++++++++++++
 .../wayang/sqlite3/operators/Sqlite3TableSource.java   | 18 ++++++++++++++++++
 .../wayang/sqlite3/platform/Sqlite3Platform.java       | 18 ++++++++++++++++++
 .../wayang/sqlite3/plugin/Sqlite3ConversionPlugin.java | 18 ++++++++++++++++++
 .../apache/wayang/sqlite3/plugin/Sqlite3Plugin.java    | 18 ++++++++++++++++++
 12 files changed, 209 insertions(+)

diff --git a/wayang-platforms/wayang-sqlite3/pom.xml b/wayang-platforms/wayang-sqlite3/pom.xml
index 25d993d..cee47c7 100644
--- a/wayang-platforms/wayang-sqlite3/pom.xml
+++ b/wayang-platforms/wayang-sqlite3/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/Sqlite3.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/Sqlite3.java
index 89506e5..3cac85b 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/Sqlite3.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/Sqlite3.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3;
 
 import org.apache.wayang.sqlite3.platform.Sqlite3Platform;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/channels/ChannelConversions.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/channels/ChannelConversions.java
index 22fa6b0..ae9fbdf 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.channels;
 
 import org.apache.wayang.core.optimizer.channels.ChannelConversion;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/FilterMapping.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/FilterMapping.java
index 8ea24e7..eeb0ac9 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/FilterMapping.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/FilterMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.mapping;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/Mappings.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/Mappings.java
index 653033d..42bfc94 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/Mappings.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/ProjectionMapping.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/ProjectionMapping.java
index e6861c3..7fc8eee 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/ProjectionMapping.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/mapping/ProjectionMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.mapping;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3FilterOperator.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3FilterOperator.java
index 6f59d33..ecad5ec 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3FilterOperator.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3FilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3ProjectionOperator.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3ProjectionOperator.java
index 97714dd..e1a8e81 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3ProjectionOperator.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3ProjectionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3TableSource.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3TableSource.java
index 9926d19..cce4163 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3TableSource.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/operators/Sqlite3TableSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.operators;
 
 import org.apache.wayang.basic.operators.TableSource;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/platform/Sqlite3Platform.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/platform/Sqlite3Platform.java
index 6a1d92e..baa00e6 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/platform/Sqlite3Platform.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/platform/Sqlite3Platform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.platform;
 
 import org.apache.wayang.core.platform.Platform;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3ConversionPlugin.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3ConversionPlugin.java
index bc415a2..4617c1f 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3ConversionPlugin.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3ConversionPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3Plugin.java b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3Plugin.java
index c041c05..a3189aa 100644
--- a/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3Plugin.java
+++ b/wayang-platforms/wayang-sqlite3/src/main/java/org/apache/wayang/sqlite3/plugin/Sqlite3Plugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.sqlite3.plugin;
 
 import org.apache.wayang.core.api.Configuration;


[incubator-wayang] 05/16: Add header licence to files in wayang-core

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit e3d111642433e9b2f49511786d6abaa52505b81c
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:14:38 2021 -0300

    Add header licence to files in wayang-core
---
 wayang-core/pom.xml                                    | 11 +++++++++++
 .../antlr4/org/apache/wayang/core/mathex/MathEx.g4     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/api/Configuration.java | 18 ++++++++++++++++++
 .../src/main/java/org/apache/wayang/core/api/Job.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/api/WayangContext.java | 18 ++++++++++++++++++
 .../core/api/configuration/CollectionProvider.java     | 18 ++++++++++++++++++
 .../core/api/configuration/ConstantValueProvider.java  | 18 ++++++++++++++++++
 .../api/configuration/ExplicitCollectionProvider.java  | 18 ++++++++++++++++++
 .../configuration/FunctionalCollectionProvider.java    | 18 ++++++++++++++++++
 .../api/configuration/FunctionalKeyValueProvider.java  | 18 ++++++++++++++++++
 .../api/configuration/FunctionalValueProvider.java     | 18 ++++++++++++++++++
 .../core/api/configuration/KeyValueProvider.java       | 18 ++++++++++++++++++
 .../api/configuration/MapBasedKeyValueProvider.java    | 18 ++++++++++++++++++
 .../wayang/core/api/configuration/ValueProvider.java   | 18 ++++++++++++++++++
 .../wayang/core/api/exception/WayangException.java     | 18 ++++++++++++++++++
 .../wayang/core/function/AggregationDescriptor.java    | 18 ++++++++++++++++++
 .../wayang/core/function/ConsumerDescriptor.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ExecutionContext.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ExtendedFunction.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/function/FlatMapDescriptor.java | 18 ++++++++++++++++++
 .../wayang/core/function/FunctionDescriptor.java       | 18 ++++++++++++++++++
 .../wayang/core/function/MapPartitionsDescriptor.java  | 18 ++++++++++++++++++
 .../wayang/core/function/PredicateDescriptor.java      | 18 ++++++++++++++++++
 .../apache/wayang/core/function/ReduceDescriptor.java  | 18 ++++++++++++++++++
 .../wayang/core/function/TransformationDescriptor.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/mapping/Mapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/mapping/OperatorMatch.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/mapping/OperatorPattern.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/mapping/PlanTransformation.java | 18 ++++++++++++++++++
 .../wayang/core/mapping/ReplacementSubplanFactory.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/mapping/SubplanMatch.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/mapping/SubplanPattern.java | 18 ++++++++++++++++++
 .../apache/wayang/core/monitor/DisabledMonitor.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/FileMonitor.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/HttpMonitor.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/monitor/Monitor.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/core/monitor/ZeroMQMonitor.java  | 18 ++++++++++++++++++
 .../core/optimizer/AggregateOptimizationContext.java   | 18 ++++++++++++++++++
 .../core/optimizer/DefaultOptimizationContext.java     | 18 ++++++++++++++++++
 .../wayang/core/optimizer/OptimizationContext.java     | 18 ++++++++++++++++++
 .../wayang/core/optimizer/OptimizationUtils.java       | 18 ++++++++++++++++++
 .../core/optimizer/ProbabilisticDoubleInterval.java    | 18 ++++++++++++++++++
 .../core/optimizer/ProbabilisticIntervalEstimate.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/optimizer/SanityChecker.java    | 18 ++++++++++++++++++
 .../AbstractAlternativeCardinalityPusher.java          | 18 ++++++++++++++++++
 .../cardinality/AggregatingCardinalityEstimator.java   | 18 ++++++++++++++++++
 .../optimizer/cardinality/CardinalityEstimate.java     | 18 ++++++++++++++++++
 .../cardinality/CardinalityEstimationTraversal.java    | 18 ++++++++++++++++++
 .../optimizer/cardinality/CardinalityEstimator.java    | 18 ++++++++++++++++++
 .../cardinality/CardinalityEstimatorManager.java       | 18 ++++++++++++++++++
 .../core/optimizer/cardinality/CardinalityPusher.java  | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityEstimator.java       | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityPusher.java          | 18 ++++++++++++++++++
 .../cardinality/FallbackCardinalityEstimator.java      | 18 ++++++++++++++++++
 .../cardinality/FixedSizeCardinalityEstimator.java     | 18 ++++++++++++++++++
 .../LoopHeadAlternativeCardinalityPusher.java          | 18 ++++++++++++++++++
 .../cardinality/LoopSubplanCardinalityPusher.java      | 18 ++++++++++++++++++
 .../OperatorAlternativeCardinalityPusher.java          | 18 ++++++++++++++++++
 .../cardinality/SubplanCardinalityPusher.java          | 18 ++++++++++++++++++
 .../cardinality/SwitchForwardCardinalityEstimator.java | 18 ++++++++++++++++++
 .../core/optimizer/channels/ChannelConversion.java     | 18 ++++++++++++++++++
 .../optimizer/channels/ChannelConversionGraph.java     | 18 ++++++++++++++++++
 .../optimizer/channels/DefaultChannelConversion.java   | 18 ++++++++++++++++++
 .../optimizer/costs/ConstantLoadProfileEstimator.java  | 18 ++++++++++++++++++
 .../core/optimizer/costs/DefaultLoadEstimator.java     | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/EstimationContext.java | 18 ++++++++++++++++++
 .../core/optimizer/costs/IntervalLoadEstimator.java    | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadEstimate.java      | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadEstimator.java     | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/LoadProfile.java       | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadProfileEstimator.java     | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadProfileEstimators.java    | 18 ++++++++++++++++++
 .../optimizer/costs/LoadProfileToTimeConverter.java    | 18 ++++++++++++++++++
 .../core/optimizer/costs/LoadToTimeConverter.java      | 18 ++++++++++++++++++
 .../optimizer/costs/NestableLoadProfileEstimator.java  | 18 ++++++++++++++++++
 .../core/optimizer/costs/SimpleEstimationContext.java  | 18 ++++++++++++++++++
 .../wayang/core/optimizer/costs/TimeEstimate.java      | 18 ++++++++++++++++++
 .../core/optimizer/costs/TimeToCostConverter.java      | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/ExecutionTaskFlow.java  | 18 ++++++++++++++++++
 .../enumeration/ExecutionTaskFlowCompiler.java         | 18 ++++++++++++++++++
 .../enumeration/LatentOperatorPruningStrategy.java     | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/LoopEnumerator.java     | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/LoopImplementation.java | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/PlanEnumeration.java    | 18 ++++++++++++++++++
 .../enumeration/PlanEnumerationPruningStrategy.java    | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/PlanEnumerator.java     | 18 ++++++++++++++++++
 .../core/optimizer/enumeration/PlanImplementation.java | 18 ++++++++++++++++++
 .../optimizer/enumeration/RandomPruningStrategy.java   | 18 ++++++++++++++++++
 .../enumeration/SinglePlatformPruningStrategy.java     | 18 ++++++++++++++++++
 .../enumeration/StageAssignmentTraversal.java          | 18 ++++++++++++++++++
 .../optimizer/enumeration/TopKPruningStrategy.java     | 18 ++++++++++++++++++
 .../optimizer/partition/EnumerationAlternative.java    | 18 ++++++++++++++++++
 .../core/optimizer/partition/EnumerationBranch.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/executionplan/Channel.java | 18 ++++++++++++++++++
 .../core/plan/executionplan/ChannelInitializer.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/ExecutionPlan.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/ExecutionStage.java | 18 ++++++++++++++++++
 .../core/plan/executionplan/ExecutionStageLoop.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/executionplan/ExecutionTask.java  | 18 ++++++++++++++++++
 .../core/plan/executionplan/PlatformExecution.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/ActualOperator.java    | 18 ++++++++++++++++++
 .../core/plan/wayangplan/BinaryToUnaryOperator.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/CompositeOperator.java | 18 ++++++++++++++++++
 .../core/plan/wayangplan/ElementaryOperator.java       | 18 ++++++++++++++++++
 .../plan/wayangplan/EstimationContextProperty.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/ExecutionOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/InputSlot.java  | 18 ++++++++++++++++++
 .../core/plan/wayangplan/LoopHeadAlternative.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopHeadOperator.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopIsolator.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopSubplan.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Operator.java   | 18 ++++++++++++++++++
 .../core/plan/wayangplan/OperatorAlternative.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OperatorBase.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OperatorContainer.java | 18 ++++++++++++++++++
 .../core/plan/wayangplan/OperatorContainers.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Operators.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/OutputSlot.java | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/PlanMetrics.java       | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/PlanTraversal.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/plan/wayangplan/Slot.java   | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/SlotMapping.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/Subplan.java    | 18 ++++++++++++++++++
 .../core/plan/wayangplan/TopDownPlanVisitor.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/UnarySink.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/UnarySource.java       | 18 ++++++++++++++++++
 .../core/plan/wayangplan/UnaryToUnaryOperator.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/plan/wayangplan/WayangPlan.java | 18 ++++++++++++++++++
 .../traversal/AbstractTopologicalTraversal.java        | 18 ++++++++++++++++++
 .../wayang/core/platform/AbstractChannelInstance.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/AtomicExecution.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/AtomicExecutionGroup.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/Breakpoint.java    | 18 ++++++++++++++++++
 .../wayang/core/platform/CardinalityBreakpoint.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ChannelDescriptor.java | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ChannelInstance.java   | 18 ++++++++++++++++++
 .../core/platform/CompositeExecutionResource.java      | 18 ++++++++++++++++++
 .../wayang/core/platform/ConjunctiveBreakpoint.java    | 18 ++++++++++++++++++
 .../wayang/core/platform/CrossPlatformExecutor.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ExecutionResource.java | 18 ++++++++++++++++++
 .../core/platform/ExecutionResourceTemplate.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ExecutionState.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/platform/Executor.java | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/ExecutorTemplate.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/platform/FixBreakpoint.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/platform/Junction.java | 18 ++++++++++++++++++
 .../wayang/core/platform/NoIterationBreakpoint.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/platform/PartialExecution.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/platform/Platform.java | 18 ++++++++++++++++++
 .../wayang/core/platform/PushExecutorTemplate.java     | 18 ++++++++++++++++++
 .../core/platform/lineage/ChannelLineageNode.java      | 18 ++++++++++++++++++
 .../core/platform/lineage/ExecutionLineageNode.java    | 18 ++++++++++++++++++
 .../platform/lineage/LazyExecutionLineageNode.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/plugin/DynamicPlugin.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/plugin/Plugin.java     | 18 ++++++++++++++++++
 .../wayang/core/profiling/CardinalityRepository.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/profiling/CostMeasurement.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/profiling/ExecutionLog.java | 18 ++++++++++++++++++
 .../core/profiling/ExecutionPlanMeasurement.java       | 18 ++++++++++++++++++
 .../core/profiling/FullInstrumentationStrategy.java    | 18 ++++++++++++++++++
 .../wayang/core/profiling/InstrumentationStrategy.java | 18 ++++++++++++++++++
 .../core/profiling/NoInstrumentationStrategy.java      | 18 ++++++++++++++++++
 .../profiling/OutboundInstrumentationStrategy.java     | 18 ++++++++++++++++++
 .../core/profiling/PartialExecutionMeasurement.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/profiling/ProfileDBs.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/types/BasicDataUnitType.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/types/DataSetType.java | 18 ++++++++++++++++++
 .../apache/wayang/core/types/DataUnitGroupType.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/types/DataUnitType.java     | 18 ++++++++++++++++++
 .../wayang/core/util/AbstractReferenceCountable.java   | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Action.java  | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Actions.java | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Bitmask.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/Canonicalizer.java     | 18 ++++++++++++++++++
 .../wayang/core/util/ConsumerIteratorAdapter.java      | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Copyable.java     | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Counter.java | 18 ++++++++++++++++++
 .../apache/wayang/core/util/CrossProductIterable.java  | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Formats.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Iterators.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/JsonSerializable.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/JsonSerializables.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/JsonSerializer.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/JuelUtils.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/util/LimitedInputStream.java    | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Logging.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/LruCache.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/MultiMap.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/OneTimeExecutable.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/Optional.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/util/ReferenceCountable.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/ReflectionUtils.java   | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/core/util/Tuple.java   | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/WayangArrays.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/WayangCollections.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/fs/FileSystem.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/fs/FileSystems.java    | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/fs/FileUtils.java | 18 ++++++++++++++++++
 .../apache/wayang/core/util/fs/HadoopFileSystem.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/util/fs/LocalFileSystem.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/mathex/Context.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/util/mathex/DefaultContext.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/util/mathex/Expression.java | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/ExpressionBuilder.java     | 18 ++++++++++++++++++
 .../util/mathex/exceptions/EvaluationException.java    | 18 ++++++++++++++++++
 .../core/util/mathex/exceptions/MathExException.java   | 18 ++++++++++++++++++
 .../core/util/mathex/exceptions/ParseException.java    | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/BinaryOperation.java | 18 ++++++++++++++++++
 .../core/util/mathex/model/CompiledFunction.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/util/mathex/model/Constant.java | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/NamedFunction.java   | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/model/UnaryOperation.java  | 18 ++++++++++++++++++
 .../apache/wayang/core/util/mathex/model/Variable.java | 18 ++++++++++++++++++
 .../src/test/java/org/apache/wayang/core/SlotTest.java | 18 ++++++++++++++++++
 .../wayang/core/mapping/OperatorPatternTest.java       | 18 ++++++++++++++++++
 .../wayang/core/mapping/PlanTransformationTest.java    | 18 ++++++++++++++++++
 .../apache/wayang/core/mapping/SubplanPatternTest.java | 18 ++++++++++++++++++
 .../wayang/core/mapping/test/TestSinkMapping.java      | 18 ++++++++++++++++++
 .../core/mapping/test/TestSinkToTestSink2Factory.java  | 18 ++++++++++++++++++
 .../AggregatingCardinalityEstimatorTest.java           | 18 ++++++++++++++++++
 .../cardinality/DefaultCardinalityEstimatorTest.java   | 18 ++++++++++++++++++
 .../cardinality/LoopSubplanCardinalityPusherTest.java  | 18 ++++++++++++++++++
 .../cardinality/SubplanCardinalityPusherTest.java      | 18 ++++++++++++++++++
 .../optimizer/channels/ChannelConversionGraphTest.java | 18 ++++++++++++++++++
 .../costs/NestableLoadProfileEstimatorTest.java        | 18 ++++++++++++++++++
 .../enumeration/StageAssignmentTraversalTest.java      | 18 ++++++++++++++++++
 .../core/plan/executionplan/test/TestChannel.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/LoopIsolatorTest.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/OperatorTest.java      | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/SlotMappingTest.java   | 18 ++++++++++++++++++
 .../plan/wayangplan/test/TestCustomMapOperator.java    | 18 ++++++++++++++++++
 .../core/plan/wayangplan/test/TestFilterOperator.java  | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestJoin.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestLoopHead.java | 18 ++++++++++++++++++
 .../core/plan/wayangplan/test/TestMapOperator.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSink.java     | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSink2.java    | 18 ++++++++++++++++++
 .../wayang/core/plan/wayangplan/test/TestSource.java   | 18 ++++++++++++++++++
 .../wayang/core/platform/PartialExecutionTest.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/plugin/DynamicPluginTest.java   | 18 ++++++++++++++++++
 .../wayang/core/test/DummyExecutionOperator.java       | 18 ++++++++++++++++++
 .../wayang/core/test/DummyExternalReusableChannel.java | 18 ++++++++++++++++++
 .../wayang/core/test/DummyNonReusableChannel.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/core/test/DummyPlatform.java     | 18 ++++++++++++++++++
 .../apache/wayang/core/test/DummyReusableChannel.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/test/MockFactory.java  | 18 ++++++++++++++++++
 .../core/test/SerializableDummyExecutionOperator.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/test/TestDataUnit.java | 18 ++++++++++++++++++
 .../org/apache/wayang/core/test/TestDataUnit2.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/core/util/BitmaskTest.java  | 18 ++++++++++++++++++
 .../wayang/core/util/ConsumerIteratorAdapterTest.java  | 18 ++++++++++++++++++
 .../wayang/core/util/CrossProductIterableTest.java     | 18 ++++++++++++++++++
 .../wayang/core/util/LimitedInputStreamTest.java       | 18 ++++++++++++++++++
 .../apache/wayang/core/util/ReflectionUtilsTest.java   | 18 ++++++++++++++++++
 .../apache/wayang/core/util/WayangCollectionsTest.java | 18 ++++++++++++++++++
 .../wayang/core/util/mathex/ExpressionBuilderTest.java | 18 ++++++++++++++++++
 .../apache/wayang/core/util/mathex/ExpressionTest.java | 18 ++++++++++++++++++
 257 files changed, 4619 insertions(+)

diff --git a/wayang-core/pom.xml b/wayang-core/pom.xml
index 915e1bf..4132a99 100644
--- a/wayang-core/pom.xml
+++ b/wayang-core/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-core/src/main/antlr4/org/apache/wayang/core/mathex/MathEx.g4 b/wayang-core/src/main/antlr4/org/apache/wayang/core/mathex/MathEx.g4
index 7c480fd..8a5171c 100644
--- a/wayang-core/src/main/antlr4/org/apache/wayang/core/mathex/MathEx.g4
+++ b/wayang-core/src/main/antlr4/org/apache/wayang/core/mathex/MathEx.g4
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
+
 grammar MathEx;
 
 options {
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/Configuration.java b/wayang-core/src/main/java/org/apache/wayang/core/api/Configuration.java
index 0cf57b8..d6a3ea9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/Configuration.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/Configuration.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/Job.java b/wayang-core/src/main/java/org/apache/wayang/core/api/Job.java
index a9935bc..c68a3f5 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/Job.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/Job.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api;
 
 import de.hpi.isg.profiledb.instrumentation.StopWatch;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/WayangContext.java b/wayang-core/src/main/java/org/apache/wayang/core/api/WayangContext.java
index 4ae3d4c..f30d31e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/WayangContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/WayangContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api;
 
 import de.hpi.isg.profiledb.store.model.Experiment;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/CollectionProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/CollectionProvider.java
index 31c6a26..4c370a6 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/CollectionProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/CollectionProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ConstantValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ConstantValueProvider.java
index a8db06d..1b0215d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ConstantValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ConstantValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ExplicitCollectionProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ExplicitCollectionProvider.java
index b2e1ac6..32a5cdf 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ExplicitCollectionProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ExplicitCollectionProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalCollectionProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalCollectionProvider.java
index aefa902..d18211a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalCollectionProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalCollectionProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalKeyValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalKeyValueProvider.java
index c133ada..a567ab6 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalKeyValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalKeyValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalValueProvider.java
index 5c704db..d861290 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/FunctionalValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/KeyValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/KeyValueProvider.java
index 574f404..071d76f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/KeyValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/KeyValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/MapBasedKeyValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/MapBasedKeyValueProvider.java
index 1f50fdb..96881d9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/MapBasedKeyValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/MapBasedKeyValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ValueProvider.java b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ValueProvider.java
index 7723064..17b0870 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ValueProvider.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/configuration/ValueProvider.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.configuration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/api/exception/WayangException.java b/wayang-core/src/main/java/org/apache/wayang/core/api/exception/WayangException.java
index 92910a4..ed03953 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/api/exception/WayangException.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/api/exception/WayangException.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.api.exception;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/AggregationDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/AggregationDescriptor.java
index 91ea506..b1a6c4a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/AggregationDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/AggregationDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.costs.LoadEstimator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/ConsumerDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/ConsumerDescriptor.java
index cc4c1ad..83221bd 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/ConsumerDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/ConsumerDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/ExecutionContext.java b/wayang-core/src/main/java/org/apache/wayang/core/function/ExecutionContext.java
index bd86a61..a870ef0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/ExecutionContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/ExecutionContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.plan.wayangplan.LoopSubplan;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/ExtendedFunction.java b/wayang-core/src/main/java/org/apache/wayang/core/function/ExtendedFunction.java
index c95e45a..808dcd0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/ExtendedFunction.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/ExtendedFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.plan.wayangplan.Operator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/FlatMapDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/FlatMapDescriptor.java
index a4d2fa1..948af92 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/FlatMapDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/FlatMapDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/FunctionDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/FunctionDescriptor.java
index 1253d08..18d13e0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/FunctionDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/FunctionDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/MapPartitionsDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/MapPartitionsDescriptor.java
index 9c361dc..d93833c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/MapPartitionsDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/MapPartitionsDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/PredicateDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/PredicateDescriptor.java
index 18f8334..6b90e27 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/PredicateDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/PredicateDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/ReduceDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/ReduceDescriptor.java
index fd29548..0bd3853 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/ReduceDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/ReduceDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.costs.LoadEstimator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/function/TransformationDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/function/TransformationDescriptor.java
index e295f25..3de70e7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/function/TransformationDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/function/TransformationDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.function;
 
 import org.apache.wayang.core.optimizer.costs.LoadEstimator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/Mapping.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/Mapping.java
index e8769f4..194da2b 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/Mapping.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/Mapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import java.util.Collection;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorMatch.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorMatch.java
index 917e68e..9dcb4e5 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorMatch.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorMatch.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.wayang.core.plan.wayangplan.Operator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorPattern.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorPattern.java
index 63deae3..03de5b2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorPattern.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/OperatorPattern.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.wayang.core.plan.wayangplan.InputSlot;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/PlanTransformation.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/PlanTransformation.java
index d777723..1bb0448 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/PlanTransformation.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/PlanTransformation.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.wayang.core.plan.wayangplan.InputSlot;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/ReplacementSubplanFactory.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/ReplacementSubplanFactory.java
index 181ddc6..9315f65 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/ReplacementSubplanFactory.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/ReplacementSubplanFactory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanMatch.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanMatch.java
index 345ba35..5f100b3 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanMatch.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanMatch.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.wayang.core.plan.wayangplan.Operator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanPattern.java b/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanPattern.java
index 4349d5f..a53065d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanPattern.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/mapping/SubplanPattern.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/monitor/DisabledMonitor.java b/wayang-core/src/main/java/org/apache/wayang/core/monitor/DisabledMonitor.java
index ec20bb5..ebb598b 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/monitor/DisabledMonitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/monitor/DisabledMonitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.monitor;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/monitor/FileMonitor.java b/wayang-core/src/main/java/org/apache/wayang/core/monitor/FileMonitor.java
index 7e427e1..f6e6998 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/monitor/FileMonitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/monitor/FileMonitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.monitor;
 
 
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/monitor/HttpMonitor.java b/wayang-core/src/main/java/org/apache/wayang/core/monitor/HttpMonitor.java
index 6f3b386..dda6335 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/monitor/HttpMonitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/monitor/HttpMonitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.monitor;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/monitor/Monitor.java b/wayang-core/src/main/java/org/apache/wayang/core/monitor/Monitor.java
index 9594faf..2d5e7c9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/monitor/Monitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/monitor/Monitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.monitor;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/monitor/ZeroMQMonitor.java b/wayang-core/src/main/java/org/apache/wayang/core/monitor/ZeroMQMonitor.java
index e47ee5d..c031032 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/monitor/ZeroMQMonitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/monitor/ZeroMQMonitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.monitor;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/AggregateOptimizationContext.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/AggregateOptimizationContext.java
index faeec03..964d94a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/AggregateOptimizationContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/AggregateOptimizationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.plan.wayangplan.LoopSubplan;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/DefaultOptimizationContext.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/DefaultOptimizationContext.java
index 738bdc1..187979d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/DefaultOptimizationContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/DefaultOptimizationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.api.Job;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationContext.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationContext.java
index 75fc17e..2b6e673 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationUtils.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationUtils.java
index 9775c30..3f71b5d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationUtils.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/OptimizationUtils.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticDoubleInterval.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticDoubleInterval.java
index f29871d..66f7e20 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticDoubleInterval.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticDoubleInterval.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import java.util.Objects;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticIntervalEstimate.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticIntervalEstimate.java
index 58a0c5e..5e8a112 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticIntervalEstimate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/ProbabilisticIntervalEstimate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.util.Formats;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/SanityChecker.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/SanityChecker.java
index 834fe32..e7d3964 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/SanityChecker.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/SanityChecker.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer;
 
 import org.apache.wayang.core.plan.wayangplan.Operator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AbstractAlternativeCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AbstractAlternativeCardinalityPusher.java
index 11a9912..f6b9a9d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AbstractAlternativeCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AbstractAlternativeCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimator.java
index 4d7e91c..7d404a1 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimate.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimate.java
index e8c528f..1bd5987 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimationTraversal.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimationTraversal.java
index be1f9b5..7dc5ae9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimationTraversal.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimationTraversal.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimator.java
index 604ee5b..d95fb01 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimatorManager.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimatorManager.java
index fb1ad8f..ab935c0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimatorManager.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityEstimatorManager.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityPusher.java
index dcf8bcb..a19ca72 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/CardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimator.java
index 47b3ab4..7582261 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityPusher.java
index 401c03f..c9f61f8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FallbackCardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FallbackCardinalityEstimator.java
index ea208f1..3cc0ab1 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FallbackCardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FallbackCardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FixedSizeCardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FixedSizeCardinalityEstimator.java
index 9f7ab2c..771a675 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FixedSizeCardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/FixedSizeCardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopHeadAlternativeCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopHeadAlternativeCardinalityPusher.java
index 7fb7807..67a1b7a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopHeadAlternativeCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopHeadAlternativeCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusher.java
index 8c06311..4834bc2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/OperatorAlternativeCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/OperatorAlternativeCardinalityPusher.java
index ccd21b6..d5886fc 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/OperatorAlternativeCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/OperatorAlternativeCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusher.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusher.java
index 1537da5..50184bc 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusher.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusher.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SwitchForwardCardinalityEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SwitchForwardCardinalityEstimator.java
index 3e4e1c1..b91fd8c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SwitchForwardCardinalityEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/cardinality/SwitchForwardCardinalityEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversion.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversion.java
index 51e4c9f..95590a8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversion.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversion.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.channels;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraph.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraph.java
index a6e4c45..d30d163 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraph.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraph.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.channels;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/DefaultChannelConversion.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/DefaultChannelConversion.java
index 7a1dafc..d4c97a8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/DefaultChannelConversion.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/channels/DefaultChannelConversion.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.channels;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/ConstantLoadProfileEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/ConstantLoadProfileEstimator.java
index e77ce03..84150e7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/ConstantLoadProfileEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/ConstantLoadProfileEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import java.util.Collection;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/DefaultLoadEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/DefaultLoadEstimator.java
index b52d756..775129e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/DefaultLoadEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/DefaultLoadEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/EstimationContext.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/EstimationContext.java
index 83f8fb1..b990ba9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/EstimationContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/EstimationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/IntervalLoadEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/IntervalLoadEstimator.java
index 1cd0402..2d7d697 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/IntervalLoadEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/IntervalLoadEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimate.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimate.java
index 722de22..8453d87 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimator.java
index 12aa25b..0f07067 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.wayang.core.function.FunctionDescriptor;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfile.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfile.java
index 6f48836..b367589 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfile.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfile.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimator.java
index 20653cb..1eb2dc3 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimators.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimators.java
index 67ebaff..2be8675 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimators.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileEstimators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileToTimeConverter.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileToTimeConverter.java
index 002a1a7..c74890f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileToTimeConverter.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadProfileToTimeConverter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import java.util.Objects;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadToTimeConverter.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadToTimeConverter.java
index 45ad79a..ea504d7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadToTimeConverter.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/LoadToTimeConverter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimator.java
index aae81bb..7bd64c2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/SimpleEstimationContext.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/SimpleEstimationContext.java
index 619bb1a..bd2367b 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/SimpleEstimationContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/SimpleEstimationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import gnu.trove.map.TObjectDoubleMap;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeEstimate.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeEstimate.java
index 93d1168..56bfd55 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeEstimate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeEstimate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.wayang.core.optimizer.ProbabilisticIntervalEstimate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeToCostConverter.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeToCostConverter.java
index 122ca38..4133e2c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeToCostConverter.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/costs/TimeToCostConverter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlow.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlow.java
index 0e0a9ee..9d80676 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlow.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlow.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlowCompiler.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlowCompiler.java
index 1c06756..04974af 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlowCompiler.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/ExecutionTaskFlowCompiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.optimizer.OptimizationUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LatentOperatorPruningStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LatentOperatorPruningStrategy.java
index 298f4d1..8d8ec6f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LatentOperatorPruningStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LatentOperatorPruningStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopEnumerator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopEnumerator.java
index 3fdfcd7..2b106f7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopEnumerator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopEnumerator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopImplementation.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopImplementation.java
index 99f4040..57416fa 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopImplementation.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/LoopImplementation.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.optimizer.ProbabilisticDoubleInterval;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumeration.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumeration.java
index 529f93c..f1f4075 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumeration.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumeration.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import de.hpi.isg.profiledb.store.model.TimeMeasurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerationPruningStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerationPruningStrategy.java
index a4245d5..a3965f2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerationPruningStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerationPruningStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerator.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerator.java
index 0c624c4..19039ad 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanEnumerator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import de.hpi.isg.profiledb.store.model.TimeMeasurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanImplementation.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanImplementation.java
index b469932..033b23e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanImplementation.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/PlanImplementation.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/RandomPruningStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/RandomPruningStrategy.java
index 3a2ffb4..c10eb32 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/RandomPruningStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/RandomPruningStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/SinglePlatformPruningStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/SinglePlatformPruningStrategy.java
index 395f663..4d04261 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/SinglePlatformPruningStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/SinglePlatformPruningStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversal.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversal.java
index 010eea2..d24b514 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversal.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversal.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/TopKPruningStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/TopKPruningStrategy.java
index 9bf6868..a80f9d9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/TopKPruningStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/enumeration/TopKPruningStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationAlternative.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationAlternative.java
index a864221..b44dff8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationAlternative.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationAlternative.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.partition;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationBranch.java b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationBranch.java
index a7587de..67bce68 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationBranch.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/optimizer/partition/EnumerationBranch.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.partition;
 
 import org.apache.wayang.core.plan.executionplan.ExecutionPlan;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/Channel.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/Channel.java
index 73394aa..32b1dfe 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/Channel.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/Channel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ChannelInitializer.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ChannelInitializer.java
index c183418..72c2753 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ChannelInitializer.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ChannelInitializer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionPlan.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionPlan.java
index 282815e..e4acb05 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionPlan.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionPlan.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStage.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStage.java
index 3b674a9..ced3433 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStage.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStage.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStageLoop.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStageLoop.java
index 18ddc21..b2b6e94 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStageLoop.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionStageLoop.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.wayang.core.plan.wayangplan.ExecutionOperator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionTask.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionTask.java
index 8f2e72d..75e0cc0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionTask.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/ExecutionTask.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/PlatformExecution.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/PlatformExecution.java
index ef222d3..877eba4 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/PlatformExecution.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/executionplan/PlatformExecution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ActualOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ActualOperator.java
index b631df1..e8ef8f8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ActualOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ActualOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/BinaryToUnaryOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/BinaryToUnaryOperator.java
index 322c55c..b9658ed 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/BinaryToUnaryOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/BinaryToUnaryOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/CompositeOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/CompositeOperator.java
index 7423203..c11c275 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/CompositeOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/CompositeOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import java.util.Collection;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ElementaryOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ElementaryOperator.java
index f90f410..b56f05a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ElementaryOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ElementaryOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/EstimationContextProperty.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/EstimationContextProperty.java
index 3a431e0..c64ac69 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/EstimationContextProperty.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/EstimationContextProperty.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.optimizer.costs.EstimationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ExecutionOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ExecutionOperator.java
index f2da41a..c3b85ce 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ExecutionOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/ExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/InputSlot.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/InputSlot.java
index 88f5d94..6713f48 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/InputSlot.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/InputSlot.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadAlternative.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadAlternative.java
index f3e585e..70d9854 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadAlternative.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadAlternative.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadOperator.java
index c940030..5db5c24 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopHeadOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopIsolator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopIsolator.java
index 0e30dfd..85d670f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopIsolator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopIsolator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopSubplan.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopSubplan.java
index 9104ace..079d071 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopSubplan.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/LoopSubplan.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operator.java
index 2a0efa9..5095342 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorAlternative.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorAlternative.java
index bc6a519..babad5d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorAlternative.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorAlternative.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorBase.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorBase.java
index a349d2f..e351b49 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorBase.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import com.google.gson.JsonDeserializationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainer.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainer.java
index ae7b2f4..eb49ea8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainer.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainers.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainers.java
index b61aff8..becd0a3 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainers.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OperatorContainers.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operators.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operators.java
index 9952d5d..54992a2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operators.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Operators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import java.util.Arrays;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OutputSlot.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OutputSlot.java
index 1619423..b9a0b91 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OutputSlot.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/OutputSlot.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanMetrics.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanMetrics.java
index b32e5e1..a6f20f7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanMetrics.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanMetrics.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import de.hpi.isg.profiledb.store.model.Measurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanTraversal.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanTraversal.java
index 0c618f1..c777097 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanTraversal.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/PlanTraversal.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.slf4j.Logger;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Slot.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Slot.java
index 3d45915..93f1488 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Slot.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Slot.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/SlotMapping.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/SlotMapping.java
index fc337ef..0916222 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/SlotMapping.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/SlotMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.util.WayangCollections;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Subplan.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Subplan.java
index bbfc235..4954f37 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Subplan.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/Subplan.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/TopDownPlanVisitor.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/TopDownPlanVisitor.java
index e24a4b1..f7a47c7 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/TopDownPlanVisitor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/TopDownPlanVisitor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import java.util.Optional;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySink.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySink.java
index 54e8669..ec8bf38 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySink.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySource.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySource.java
index 0e9cccb..9896017 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySource.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnarySource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnaryToUnaryOperator.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnaryToUnaryOperator.java
index 5d56c29..8aa30a9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnaryToUnaryOperator.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/UnaryToUnaryOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/WayangPlan.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/WayangPlan.java
index a1f36c6..60ea231 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/WayangPlan.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/WayangPlan.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/traversal/AbstractTopologicalTraversal.java b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/traversal/AbstractTopologicalTraversal.java
index b0e6ca1..df4f9d0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/traversal/AbstractTopologicalTraversal.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plan/wayangplan/traversal/AbstractTopologicalTraversal.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.traversal;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/AbstractChannelInstance.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/AbstractChannelInstance.java
index f6ac148..3e5aec0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/AbstractChannelInstance.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/AbstractChannelInstance.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecution.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecution.java
index 9e1633b..d82aa1a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecution.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.commons.lang3.SerializationException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecutionGroup.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecutionGroup.java
index 8940f14..a54511f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecutionGroup.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/AtomicExecutionGroup.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/Breakpoint.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/Breakpoint.java
index 549f240..2256d30 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/Breakpoint.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/Breakpoint.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/CardinalityBreakpoint.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/CardinalityBreakpoint.java
index 0668e26..f13d631 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/CardinalityBreakpoint.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/CardinalityBreakpoint.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelDescriptor.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelDescriptor.java
index d93219a..618609c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelDescriptor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelInstance.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelInstance.java
index ae311b7..b5a6fd5 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelInstance.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ChannelInstance.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/CompositeExecutionResource.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/CompositeExecutionResource.java
index 1b8181e..3bdcca8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/CompositeExecutionResource.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/CompositeExecutionResource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ConjunctiveBreakpoint.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ConjunctiveBreakpoint.java
index 87b0cd1..6c35138 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ConjunctiveBreakpoint.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ConjunctiveBreakpoint.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/CrossPlatformExecutor.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/CrossPlatformExecutor.java
index ac14a15..1fa89f6 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/CrossPlatformExecutor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/CrossPlatformExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResource.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResource.java
index 4f258dd..70eed9d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResource.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResourceTemplate.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResourceTemplate.java
index 440023c..ce4f200 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResourceTemplate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionResourceTemplate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionState.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionState.java
index 7aeb77d..3cd987e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionState.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutionState.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.enumeration.ExecutionTaskFlow;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/Executor.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/Executor.java
index ce8b4f9..e818344 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/Executor.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/Executor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.Job;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutorTemplate.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutorTemplate.java
index f5bffbc..0839e29 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutorTemplate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/ExecutorTemplate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/FixBreakpoint.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/FixBreakpoint.java
index f090372..f6fb93d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/FixBreakpoint.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/FixBreakpoint.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/Junction.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/Junction.java
index 4001854..15bd646 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/Junction.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/Junction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/NoIterationBreakpoint.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/NoIterationBreakpoint.java
index cfcee18..9cc61e8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/NoIterationBreakpoint.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/NoIterationBreakpoint.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/PartialExecution.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/PartialExecution.java
index d4b3a67..eeae2d8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/PartialExecution.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/PartialExecution.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/Platform.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/Platform.java
index 4624da9..9862865 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/Platform.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/Platform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/PushExecutorTemplate.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/PushExecutorTemplate.java
index e66b798..f46ae71 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/PushExecutorTemplate.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/PushExecutorTemplate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.apache.wayang.core.api.Job;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ChannelLineageNode.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ChannelLineageNode.java
index cb0c19b..323871d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ChannelLineageNode.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ChannelLineageNode.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform.lineage;
 
 import org.apache.wayang.core.platform.ChannelInstance;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ExecutionLineageNode.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ExecutionLineageNode.java
index 902c43f..7d91f7a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ExecutionLineageNode.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/ExecutionLineageNode.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform.lineage;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/LazyExecutionLineageNode.java b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/LazyExecutionLineageNode.java
index 4947af1..c5a26eb 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/LazyExecutionLineageNode.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/platform/lineage/LazyExecutionLineageNode.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform.lineage;
 
 import org.apache.wayang.core.platform.ChannelInstance;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plugin/DynamicPlugin.java b/wayang-core/src/main/java/org/apache/wayang/core/plugin/DynamicPlugin.java
index 63fe202..c0d7695 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plugin/DynamicPlugin.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plugin/DynamicPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plugin;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/plugin/Plugin.java b/wayang-core/src/main/java/org/apache/wayang/core/plugin/Plugin.java
index e4da914..a714588 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/plugin/Plugin.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/plugin/Plugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/CardinalityRepository.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/CardinalityRepository.java
index c6e0e62..6f24525 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/CardinalityRepository.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/CardinalityRepository.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/CostMeasurement.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/CostMeasurement.java
index 21c9836..e7b1199 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/CostMeasurement.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/CostMeasurement.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import de.hpi.isg.profiledb.store.model.Measurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionLog.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionLog.java
index 23ceefa..a4eea50 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionLog.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionLog.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionPlanMeasurement.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionPlanMeasurement.java
index a167dc1..679797f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionPlanMeasurement.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ExecutionPlanMeasurement.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import de.hpi.isg.profiledb.store.model.Measurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/FullInstrumentationStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/FullInstrumentationStrategy.java
index f316fa1..a90cb0d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/FullInstrumentationStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/FullInstrumentationStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/InstrumentationStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/InstrumentationStrategy.java
index d3ae331..73d4f2a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/InstrumentationStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/InstrumentationStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/NoInstrumentationStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/NoInstrumentationStrategy.java
index c3f7ac8..9a69120 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/NoInstrumentationStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/NoInstrumentationStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/OutboundInstrumentationStrategy.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/OutboundInstrumentationStrategy.java
index 4677882..c7ce5a8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/OutboundInstrumentationStrategy.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/OutboundInstrumentationStrategy.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/PartialExecutionMeasurement.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/PartialExecutionMeasurement.java
index b0ed1e1..3320f9f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/PartialExecutionMeasurement.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/PartialExecutionMeasurement.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import de.hpi.isg.profiledb.store.model.Measurement;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ProfileDBs.java b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ProfileDBs.java
index 59426ec..6e4bc85 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/profiling/ProfileDBs.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/profiling/ProfileDBs.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.profiling;
 
 import de.hpi.isg.profiledb.ProfileDB;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/types/BasicDataUnitType.java b/wayang-core/src/main/java/org/apache/wayang/core/types/BasicDataUnitType.java
index 00ec5e5..c4082e6 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/types/BasicDataUnitType.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/types/BasicDataUnitType.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.types;
 
 import java.util.Objects;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/types/DataSetType.java b/wayang-core/src/main/java/org/apache/wayang/core/types/DataSetType.java
index 3132330..cc409a8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/types/DataSetType.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/types/DataSetType.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.types;
 
 import org.apache.wayang.core.util.ReflectionUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitGroupType.java b/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitGroupType.java
index 8739ab8..af8904e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitGroupType.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitGroupType.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.types;
 
 import org.apache.wayang.core.util.ReflectionUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitType.java b/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitType.java
index ebc360a..9ae091a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitType.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/types/DataUnitType.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.types;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/AbstractReferenceCountable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/AbstractReferenceCountable.java
index f45d4f4..5c8fc3e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/AbstractReferenceCountable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/AbstractReferenceCountable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.slf4j.Logger;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Action.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Action.java
index d4942e4..f2e958f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Action.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Action.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.slf4j.LoggerFactory;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Actions.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Actions.java
index ead17b0..e87615a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Actions.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Actions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Bitmask.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Bitmask.java
index 52e3105..df75b4e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Bitmask.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Bitmask.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.NoSuchElementException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Canonicalizer.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Canonicalizer.java
index fdfa431..42f5674 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Canonicalizer.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Canonicalizer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.Collection;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/ConsumerIteratorAdapter.java b/wayang-core/src/main/java/org/apache/wayang/core/util/ConsumerIteratorAdapter.java
index ec8f62d..ffcd154 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/ConsumerIteratorAdapter.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/ConsumerIteratorAdapter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.ArrayList;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Copyable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Copyable.java
index 0064a39..595eba3 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Copyable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Copyable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Counter.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Counter.java
index fec6161..148b6cf 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Counter.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Counter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.HashMap;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/CrossProductIterable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/CrossProductIterable.java
index cde789f..70cec03 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/CrossProductIterable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/CrossProductIterable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.ArrayList;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Formats.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Formats.java
index 2821640..7447f6c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Formats.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Formats.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Iterators.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Iterators.java
index 06d4726..8a457d2 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Iterators.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Iterators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.Iterator;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializable.java
index aab2010..97594b8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializables.java b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializables.java
index fa2f139..1176ecd 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializables.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializables.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.apache.commons.lang3.SerializationException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializer.java b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializer.java
index c0ddbbd..48a5447 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializer.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/JsonSerializer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.apache.commons.lang3.SerializationException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/JuelUtils.java b/wayang-core/src/main/java/org/apache/wayang/core/util/JuelUtils.java
index 443559d..1e1257d 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/JuelUtils.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/JuelUtils.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import de.odysseus.el.ExpressionFactoryImpl;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/LimitedInputStream.java b/wayang-core/src/main/java/org/apache/wayang/core/util/LimitedInputStream.java
index 48189f6..9e65993 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/LimitedInputStream.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/LimitedInputStream.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.io.IOException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Logging.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Logging.java
index adff2f9..0b00553 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Logging.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Logging.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.slf4j.Logger;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/LruCache.java b/wayang-core/src/main/java/org/apache/wayang/core/util/LruCache.java
index d6d0789..0b87241 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/LruCache.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/LruCache.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/MultiMap.java b/wayang-core/src/main/java/org/apache/wayang/core/util/MultiMap.java
index 8c757fc..574d4ff 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/MultiMap.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/MultiMap.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.HashMap;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/OneTimeExecutable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/OneTimeExecutable.java
index 4cf8980..41e0131 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/OneTimeExecutable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/OneTimeExecutable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.concurrent.atomic.AtomicBoolean;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Optional.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Optional.java
index b2d38e8..7e5c7a3 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Optional.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Optional.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.stream.Stream;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/ReferenceCountable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/ReferenceCountable.java
index b50ef90..e8577c8 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/ReferenceCountable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/ReferenceCountable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 /**
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/ReflectionUtils.java b/wayang-core/src/main/java/org/apache/wayang/core/util/ReflectionUtils.java
index 99fd519..d7ee580 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/ReflectionUtils.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/ReflectionUtils.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/Tuple.java b/wayang-core/src/main/java/org/apache/wayang/core/util/Tuple.java
index f0321f5..cb6a317 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/Tuple.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/Tuple.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.Objects;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/WayangArrays.java b/wayang-core/src/main/java/org/apache/wayang/core/util/WayangArrays.java
index 30ef6fc..9600a1a 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/WayangArrays.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/WayangArrays.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import java.util.Arrays;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/WayangCollections.java b/wayang-core/src/main/java/org/apache/wayang/core/util/WayangCollections.java
index 964476f..5b3e891 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/WayangCollections.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/WayangCollections.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystem.java b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystem.java
index ddcd042..c789d6e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystem.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystem.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.fs;
 
 import java.io.FileNotFoundException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystems.java b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystems.java
index 2f5ca3c..e3ebcb6 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystems.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileSystems.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.fs;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileUtils.java b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileUtils.java
index 0112f52..85cc0da 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileUtils.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/FileUtils.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.fs;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/HadoopFileSystem.java b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/HadoopFileSystem.java
index 32349c0..ec5c28f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/HadoopFileSystem.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/HadoopFileSystem.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.fs;
 
 import org.apache.hadoop.conf.Configuration;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/LocalFileSystem.java b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/LocalFileSystem.java
index 7945ec3..4286372 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/fs/LocalFileSystem.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/fs/LocalFileSystem.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.fs;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Context.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Context.java
index c196d10..bd01fa5 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Context.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Context.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 import org.apache.wayang.core.util.mathex.exceptions.EvaluationException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/DefaultContext.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/DefaultContext.java
index f59ec2b..0bea52c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/DefaultContext.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/DefaultContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 import org.apache.wayang.core.util.mathex.exceptions.EvaluationException;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Expression.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Expression.java
index 3c62be2..c07e010 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Expression.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/Expression.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/ExpressionBuilder.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/ExpressionBuilder.java
index 0f5ed9c..6170be4 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/ExpressionBuilder.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/ExpressionBuilder.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 import org.antlr.v4.runtime.ANTLRInputStream;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/EvaluationException.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/EvaluationException.java
index d7a928f..a29d37c 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/EvaluationException.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/EvaluationException.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.exceptions;
 
 
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/MathExException.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/MathExException.java
index 8f28826..84ff7ee 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/MathExException.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/MathExException.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.exceptions;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/ParseException.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/ParseException.java
index bf31ad3..110bacb 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/ParseException.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/exceptions/ParseException.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.exceptions;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/BinaryOperation.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/BinaryOperation.java
index a93935d..933afb0 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/BinaryOperation.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/BinaryOperation.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/CompiledFunction.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/CompiledFunction.java
index 9ab835b..11455ab 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/CompiledFunction.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/CompiledFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Constant.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Constant.java
index 5f317f1..b51cb9f 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Constant.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Constant.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/NamedFunction.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/NamedFunction.java
index f623f9b..9c26eb4 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/NamedFunction.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/NamedFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/UnaryOperation.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/UnaryOperation.java
index 5d70028..8d89a5e 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/UnaryOperation.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/UnaryOperation.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 import org.apache.wayang.core.util.mathex.Context;
diff --git a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Variable.java b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Variable.java
index 5bc62d5..e007de9 100644
--- a/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Variable.java
+++ b/wayang-core/src/main/java/org/apache/wayang/core/util/mathex/model/Variable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex.model;
 
 
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/SlotTest.java b/wayang-core/src/test/java/org/apache/wayang/core/SlotTest.java
index b99a4f2..ebc8e8a 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/SlotTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/SlotTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core;
 
 import org.junit.Test;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/mapping/OperatorPatternTest.java b/wayang-core/src/test/java/org/apache/wayang/core/mapping/OperatorPatternTest.java
index 61fa6c2..1cc7101 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/mapping/OperatorPatternTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/mapping/OperatorPatternTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/mapping/PlanTransformationTest.java b/wayang-core/src/test/java/org/apache/wayang/core/mapping/PlanTransformationTest.java
index c2ce303..d98cbb8 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/mapping/PlanTransformationTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/mapping/PlanTransformationTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/mapping/SubplanPatternTest.java b/wayang-core/src/test/java/org/apache/wayang/core/mapping/SubplanPatternTest.java
index d4bf5d4..dec530b 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/mapping/SubplanPatternTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/mapping/SubplanPatternTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkMapping.java b/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkMapping.java
index 422ef7d..8b57d34 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkMapping.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping.test;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkToTestSink2Factory.java b/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkToTestSink2Factory.java
index 36f13c4..7ed7d1b 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkToTestSink2Factory.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/mapping/test/TestSinkToTestSink2Factory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.mapping.test;
 
 import org.apache.wayang.core.mapping.OperatorMatch;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimatorTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimatorTest.java
index 2952bc9..e72d942 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimatorTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/AggregatingCardinalityEstimatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimatorTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimatorTest.java
index 125906c..5ffc3ab 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimatorTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/DefaultCardinalityEstimatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusherTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusherTest.java
index d9f8e8c..5a4583e 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusherTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/LoopSubplanCardinalityPusherTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusherTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusherTest.java
index 4851318..60b194a 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusherTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/cardinality/SubplanCardinalityPusherTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.cardinality;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraphTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraphTest.java
index e35775f..7013c6c 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraphTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/channels/ChannelConversionGraphTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.channels;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimatorTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimatorTest.java
index f42da6f..707b9e5 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimatorTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/costs/NestableLoadProfileEstimatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.costs;
 
 import gnu.trove.map.TObjectDoubleMap;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversalTest.java b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversalTest.java
index 6972506..9d3d2eb 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversalTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/optimizer/enumeration/StageAssignmentTraversalTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.optimizer.enumeration;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/executionplan/test/TestChannel.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/executionplan/test/TestChannel.java
index 1e8bec7..b721cf3 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/executionplan/test/TestChannel.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/executionplan/test/TestChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.executionplan.test;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/LoopIsolatorTest.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/LoopIsolatorTest.java
index 78b4923..6eae428 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/LoopIsolatorTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/LoopIsolatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/OperatorTest.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/OperatorTest.java
index 400fb06..4018ee1 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/OperatorTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/OperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/SlotMappingTest.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/SlotMappingTest.java
index 7b708bf..6659beb 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/SlotMappingTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/SlotMappingTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestCustomMapOperator.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestCustomMapOperator.java
index ba47384..3478968 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestCustomMapOperator.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestCustomMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.optimizer.cardinality.CardinalityEstimator;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestFilterOperator.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestFilterOperator.java
index 7713f5c..c05ad58 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestFilterOperator.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestJoin.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestJoin.java
index fde6894..6c8424e 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestJoin.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestJoin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestLoopHead.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestLoopHead.java
index 569e03e..f938da9 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestLoopHead.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestLoopHead.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestMapOperator.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestMapOperator.java
index c2eb4d5..216f0a4 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestMapOperator.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink.java
index c4b410c..e934f31 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink2.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink2.java
index d0357e4..3c4f754 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink2.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSink2.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.plan.wayangplan.UnarySink;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSource.java b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSource.java
index fb0dc62..06ea764 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSource.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plan/wayangplan/test/TestSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plan.wayangplan.test;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/platform/PartialExecutionTest.java b/wayang-core/src/test/java/org/apache/wayang/core/platform/PartialExecutionTest.java
index 5eecf51..0fc5f64 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/platform/PartialExecutionTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/platform/PartialExecutionTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.platform;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/plugin/DynamicPluginTest.java b/wayang-core/src/test/java/org/apache/wayang/core/plugin/DynamicPluginTest.java
index 95fe9fa..6fd6b39 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/plugin/DynamicPluginTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/plugin/DynamicPluginTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.plugin;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExecutionOperator.java b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExecutionOperator.java
index 8feb034..ae3e7ec 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExecutionOperator.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.apache.wayang.core.plan.wayangplan.ExecutionOperator;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExternalReusableChannel.java b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExternalReusableChannel.java
index e91ac5d..97818de 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExternalReusableChannel.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyExternalReusableChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyNonReusableChannel.java b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyNonReusableChannel.java
index a4c1f78..4270c43 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyNonReusableChannel.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyNonReusableChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyPlatform.java b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyPlatform.java
index 9df82eb..c1b381c 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyPlatform.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyReusableChannel.java b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyReusableChannel.java
index 6bfcd01..a9cda21 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/DummyReusableChannel.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/DummyReusableChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/MockFactory.java b/wayang-core/src/test/java/org/apache/wayang/core/test/MockFactory.java
index aea6d34..a125d21 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/MockFactory.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/MockFactory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.mockito.Answers;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/SerializableDummyExecutionOperator.java b/wayang-core/src/test/java/org/apache/wayang/core/test/SerializableDummyExecutionOperator.java
index 1e24127..4b60f15 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/SerializableDummyExecutionOperator.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/SerializableDummyExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 import org.json.JSONObject;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit.java b/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit.java
index d3c706f..d201f20 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 /**
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit2.java b/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit2.java
index 4ceba99..fd9f743 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit2.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/test/TestDataUnit2.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.test;
 
 /**
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/BitmaskTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/BitmaskTest.java
index 86fa38a..7fcbf48 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/BitmaskTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/BitmaskTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/ConsumerIteratorAdapterTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/ConsumerIteratorAdapterTest.java
index 9f9ddd3..9384aaf 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/ConsumerIteratorAdapterTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/ConsumerIteratorAdapterTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/CrossProductIterableTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/CrossProductIterableTest.java
index 1cf74dc..021d5c8 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/CrossProductIterableTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/CrossProductIterableTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/LimitedInputStreamTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/LimitedInputStreamTest.java
index 4f5e1ef..f757d79 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/LimitedInputStreamTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/LimitedInputStreamTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/ReflectionUtilsTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/ReflectionUtilsTest.java
index 3590c5e..380b250 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/ReflectionUtilsTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/ReflectionUtilsTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/WayangCollectionsTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/WayangCollectionsTest.java
index 9ec01cc..210e831 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/WayangCollectionsTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/WayangCollectionsTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util;
 
 import org.junit.Assert;
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionBuilderTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionBuilderTest.java
index 60a68e5..bb6c6b4 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionBuilderTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionBuilderTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 
diff --git a/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionTest.java b/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionTest.java
index b165c5a..b2ac236 100644
--- a/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionTest.java
+++ b/wayang-core/src/test/java/org/apache/wayang/core/util/mathex/ExpressionTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.core.util.mathex;
 
 import org.junit.Assert;


[incubator-wayang] 02/16: Add header licence to files in wayang-api

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 7f71ec5ee56274b940188a408ea65e6dd459294d
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 13:50:27 2021 -0300

    Add header licence to files in wayang-api
---
 wayang-api/pom.xml                                     | 12 ++++++++++++
 .../main/scala/org/apache/wayang/api/DataQuanta.scala  | 18 ++++++++++++++++++
 .../org/apache/wayang/api/DataQuantaBuilder.scala      | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/JavaPlanBuilder.scala  | 18 ++++++++++++++++++
 .../main/scala/org/apache/wayang/api/PlanBuilder.scala | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/RecordDataQuanta.scala | 18 ++++++++++++++++++
 .../apache/wayang/api/RecordDataQuantaBuilder.scala    | 18 ++++++++++++++++++
 .../main/scala/org/apache/wayang/api/graph/Edge.scala  | 18 ++++++++++++++++++
 .../org/apache/wayang/api/graph/EdgeDataQuanta.scala   | 18 ++++++++++++++++++
 .../wayang/api/graph/EdgeDataQuantaBuilder.scala       | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/graph/package.scala    | 18 ++++++++++++++++++
 .../src/main/scala/org/apache/wayang/api/package.scala | 18 ++++++++++++++++++
 .../wayang/api/util/DataQuantaBuilderCache.scala       | 18 ++++++++++++++++++
 .../wayang/api/util/DataQuantaBuilderDecorator.scala   | 18 ++++++++++++++++++
 .../scala/org/apache/wayang/api/util/TypeTrap.scala    | 18 ++++++++++++++++++
 .../test/java/org/apache/wayang/api/JavaApiTest.java   | 18 ++++++++++++++++++
 .../src/test/scala/org/apache/wayang/api/ApiTest.scala | 18 ++++++++++++++++++
 17 files changed, 300 insertions(+)

diff --git a/wayang-api/pom.xml b/wayang-api/pom.xml
index fb9fba9..8b68431 100644
--- a/wayang-api/pom.xml
+++ b/wayang-api/pom.xml
@@ -1,4 +1,16 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/DataQuanta.scala b/wayang-api/src/main/scala/org/apache/wayang/api/DataQuanta.scala
index ab5ca33..89722cc 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/DataQuanta.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/DataQuanta.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import _root_.java.lang.{Iterable => JavaIterable}
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/DataQuantaBuilder.scala b/wayang-api/src/main/scala/org/apache/wayang/api/DataQuantaBuilder.scala
index 573661e..a590795 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/DataQuantaBuilder.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/DataQuantaBuilder.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/JavaPlanBuilder.scala b/wayang-api/src/main/scala/org/apache/wayang/api/JavaPlanBuilder.scala
index 1f01888..dc9f6be 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/JavaPlanBuilder.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/JavaPlanBuilder.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import java.util.{Collection => JavaCollection}
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/PlanBuilder.scala b/wayang-api/src/main/scala/org/apache/wayang/api/PlanBuilder.scala
index d1971ce..8600e23 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/PlanBuilder.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/PlanBuilder.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import de.hpi.isg.profiledb.store.model.Experiment
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuanta.scala b/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuanta.scala
index aa8dd6b..cc95e39 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuanta.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuanta.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import org.apache.wayang.basic.data.Record
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuantaBuilder.scala b/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuantaBuilder.scala
index a4ef9ad..5af271f 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuantaBuilder.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/RecordDataQuantaBuilder.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import org.apache.wayang.api.util.DataQuantaBuilderDecorator
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/graph/Edge.scala b/wayang-api/src/main/scala/org/apache/wayang/api/graph/Edge.scala
index 8552036..1c67c21 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/graph/Edge.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/graph/Edge.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.graph
 
 /**
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuanta.scala b/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuanta.scala
index 697755f..6ac73ac 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuanta.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuanta.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.graph
 
 import org.apache.wayang.api._
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuantaBuilder.scala b/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuantaBuilder.scala
index 00428ce..17f5e32 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuantaBuilder.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/graph/EdgeDataQuantaBuilder.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.graph
 
 import org.apache.wayang.api.util.DataQuantaBuilderDecorator
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/graph/package.scala b/wayang-api/src/main/scala/org/apache/wayang/api/graph/package.scala
index 2ce793b..e43fe81 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/graph/package.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/graph/package.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import org.apache.wayang.basic.data.{Tuple2 => T2}
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/package.scala b/wayang-api/src/main/scala/org/apache/wayang/api/package.scala
index cd2852f..f17f5a5 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/package.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/package.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang
 
 import _root_.java.lang.{Class => JavaClass, Iterable => JavaIterable}
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderCache.scala b/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderCache.scala
index 01f2fe3..21decc2 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderCache.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderCache.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.util
 
 import org.apache.wayang.api.DataQuanta
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderDecorator.scala b/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderDecorator.scala
index 86b7953..8ea3dd2 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderDecorator.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/util/DataQuantaBuilderDecorator.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.util
 
 import de.hpi.isg.profiledb.store.model.Experiment
diff --git a/wayang-api/src/main/scala/org/apache/wayang/api/util/TypeTrap.scala b/wayang-api/src/main/scala/org/apache/wayang/api/util/TypeTrap.scala
index ee0ff48..d928fb5 100644
--- a/wayang-api/src/main/scala/org/apache/wayang/api/util/TypeTrap.scala
+++ b/wayang-api/src/main/scala/org/apache/wayang/api/util/TypeTrap.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api.util
 
 import org.apache.wayang.core.types.DataSetType
diff --git a/wayang-api/src/test/java/org/apache/wayang/api/JavaApiTest.java b/wayang-api/src/test/java/org/apache/wayang/api/JavaApiTest.java
index 2381b90..2d4bb6c 100644
--- a/wayang-api/src/test/java/org/apache/wayang/api/JavaApiTest.java
+++ b/wayang-api/src/test/java/org/apache/wayang/api/JavaApiTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api;
 
 import org.junit.Assert;
diff --git a/wayang-api/src/test/scala/org/apache/wayang/api/ApiTest.scala b/wayang-api/src/test/scala/org/apache/wayang/api/ApiTest.scala
index aac908b..cc05bd2 100644
--- a/wayang-api/src/test/scala/org/apache/wayang/api/ApiTest.scala
+++ b/wayang-api/src/test/scala/org/apache/wayang/api/ApiTest.scala
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.api
 
 import java.io.File


[incubator-wayang] 07/16: Add header licence to files in wayang-flink

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit ea0cac83629f57dd90633f6e932ecbfc0e2ea6d5
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:18:31 2021 -0300

    Add header licence to files in wayang-flink
---
 wayang-platforms/pom.xml                               | 11 +++++++++++
 wayang-platforms/wayang-flink/pom.xml                  | 11 +++++++++++
 .../src/main/java/org/apache/wayang/flink/Flink.java   | 18 ++++++++++++++++++
 .../wayang/flink/channels/ChannelConversions.java      | 18 ++++++++++++++++++
 .../apache/wayang/flink/channels/DataSetChannel.java   | 18 ++++++++++++++++++
 .../wayang/flink/compiler/FlinkCoGroupFunction.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/compiler/FunctionCompiler.java | 18 ++++++++++++++++++
 .../wayang/flink/compiler/KeySelectorDistinct.java     | 18 ++++++++++++++++++
 .../wayang/flink/compiler/KeySelectorFunction.java     | 18 ++++++++++++++++++
 .../wayang/flink/compiler/OutputFormatConsumer.java    | 18 ++++++++++++++++++
 .../wayang/flink/compiler/WayangFileOutputFormat.java  | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/DummyFilter.java   | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/DummyMap.java      | 18 ++++++++++++++++++
 .../flink/compiler/criterion/WayangAggregator.java     | 18 ++++++++++++++++++
 .../compiler/criterion/WayangConvergenceCriterion.java | 18 ++++++++++++++++++
 .../compiler/criterion/WayangFilterCriterion.java      | 18 ++++++++++++++++++
 .../flink/compiler/criterion/WayangListValue.java      | 18 ++++++++++++++++++
 .../wayang/flink/compiler/criterion/WayangValue.java   | 18 ++++++++++++++++++
 .../wayang/flink/execution/FlinkContextReference.java  | 18 ++++++++++++++++++
 .../wayang/flink/execution/FlinkExecutionContext.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/execution/FlinkExecutor.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/CartesianMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/CoGroupMapping.java    | 18 ++++++++++++++++++
 .../wayang/flink/mapping/CollectionSourceMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/CountMapping.java  | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/DistinctMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/DoWhileMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/FilterMapping.java | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/FlatMapMapping.java    | 18 ++++++++++++++++++
 .../flink/mapping/GlobalMaterializedGroupMapping.java  | 18 ++++++++++++++++++
 .../wayang/flink/mapping/GlobalReduceMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/GroupByMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/IntersectMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/JoinMapping.java   | 18 ++++++++++++++++++
 .../wayang/flink/mapping/LocalCallbackSinkMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/LoopMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/MapMapping.java    | 18 ++++++++++++++++++
 .../wayang/flink/mapping/MapPartitionsMapping.java     | 18 ++++++++++++++++++
 .../java/org/apache/wayang/flink/mapping/Mappings.java | 18 ++++++++++++++++++
 .../flink/mapping/MaterializedGroupByMapping.java      | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/PageRankMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/ReduceByMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/RepeatMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/SampleMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/flink/mapping/SortMapping.java   | 18 ++++++++++++++++++
 .../wayang/flink/mapping/TextFileSinkMapping.java      | 18 ++++++++++++++++++
 .../wayang/flink/mapping/TextFileSourceMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/UnionAllMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/flink/mapping/ZipWithIdMapping.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCartesianOperator.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCoGroupOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCollectionSink.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCollectionSource.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkCountOperator.java     | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkDistinctOperator.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkDoWhileOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkExecutionOperator.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkFilterOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkFlatMapOperator.java   | 18 ++++++++++++++++++
 .../FlinkGlobalMaterializedGroupOperator.java          | 18 ++++++++++++++++++
 .../flink/operators/FlinkGlobalReduceOperator.java     | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkGroupByOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkIntersectOperator.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkJoinOperator.java      | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkLocalCallbackSink.java | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkLoopOperator.java      | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkMapOperator.java       | 18 ++++++++++++++++++
 .../flink/operators/FlinkMapPartitionsOperator.java    | 18 ++++++++++++++++++
 .../operators/FlinkMaterializedGroupByOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkObjectFileSink.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkObjectFileSource.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkPageRankOperator.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkReduceByOperator.java  | 18 ++++++++++++++++++
 .../flink/operators/FlinkRepeatExpandedOperator.java   | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkRepeatOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkSampleOperator.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkSortOperator.java      | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTextFileSink.java      | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTextFileSource.java    | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkTsvFileSink.java       | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkUnionAllOperator.java  | 18 ++++++++++++++++++
 .../wayang/flink/operators/FlinkZipWithIdOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/flink/platform/FlinkPlatform.java    | 18 ++++++++++++++++++
 .../apache/wayang/flink/plugin/FlinkBasicPlugin.java   | 18 ++++++++++++++++++
 .../wayang/flink/plugin/FlinkConversionPlugin.java     | 18 ++++++++++++++++++
 .../apache/wayang/flink/plugin/FlinkGraphPlugin.java   | 18 ++++++++++++++++++
 86 files changed, 1534 insertions(+)

diff --git a/wayang-platforms/pom.xml b/wayang-platforms/pom.xml
index 3c1ba3d..dcf50b4 100644
--- a/wayang-platforms/pom.xml
+++ b/wayang-platforms/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-platforms/wayang-flink/pom.xml b/wayang-platforms/wayang-flink/pom.xml
index b234e0f..0ea9e50 100644
--- a/wayang-platforms/wayang-flink/pom.xml
+++ b/wayang-platforms/wayang-flink/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/Flink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/Flink.java
index f1393c7..2949362 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/Flink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/Flink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink;
 
 
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/ChannelConversions.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/ChannelConversions.java
index 4697948..64013a8 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.channels;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/DataSetChannel.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/DataSetChannel.java
index c75266a..5a45b82 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/DataSetChannel.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/channels/DataSetChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.channels;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FlinkCoGroupFunction.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FlinkCoGroupFunction.java
index bb85bcc..ba2764b 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FlinkCoGroupFunction.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FlinkCoGroupFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.common.functions.CoGroupFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FunctionCompiler.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FunctionCompiler.java
index ff35613..2eb5aaf 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FunctionCompiler.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/FunctionCompiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.common.functions.CoGroupFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorDistinct.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorDistinct.java
index c9cb95f..732c745 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorDistinct.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorDistinct.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.java.functions.KeySelector;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorFunction.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorFunction.java
index 54d716b..06098a3 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorFunction.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/KeySelectorFunction.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.common.typeinfo.TypeInformation;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/OutputFormatConsumer.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/OutputFormatConsumer.java
index 13ab3ed..91e67f8 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/OutputFormatConsumer.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/OutputFormatConsumer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.common.io.OutputFormat;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/WayangFileOutputFormat.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/WayangFileOutputFormat.java
index 2ac2248..05e778f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/WayangFileOutputFormat.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/WayangFileOutputFormat.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler;
 
 import org.apache.flink.api.common.io.BlockInfo;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyFilter.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyFilter.java
index 890aeec..d8565cc 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyFilter.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyFilter.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 import org.apache.flink.api.common.functions.FilterFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyMap.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyMap.java
index 33e3894..d9eb1b0 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyMap.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/DummyMap.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 import org.apache.flink.api.common.functions.MapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangAggregator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangAggregator.java
index a8e8e33..add4daf 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangAggregator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangAggregator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 import org.apache.flink.api.common.aggregators.Aggregator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangConvergenceCriterion.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangConvergenceCriterion.java
index 3b83a61..17c7e2e 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangConvergenceCriterion.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangConvergenceCriterion.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangFilterCriterion.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangFilterCriterion.java
index 1f75327..bb98c1d 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangFilterCriterion.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangFilterCriterion.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 import org.apache.flink.api.common.functions.AbstractRichFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangListValue.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangListValue.java
index dba7900..2333e3b 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangListValue.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangListValue.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 import org.apache.flink.types.ListValue;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangValue.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangValue.java
index ba06ca6..2fc0d6b 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangValue.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/compiler/criterion/WayangValue.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.compiler.criterion;
 
 
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkContextReference.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkContextReference.java
index 6a5fe6b..7546f05 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkContextReference.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkContextReference.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.execution;
 
 import org.apache.flink.api.common.ExecutionMode;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutionContext.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutionContext.java
index 329f2db..a14b38d 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutionContext.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutionContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.execution;
 
 import org.apache.flink.api.common.functions.RichFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutor.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutor.java
index 65a75bd..61eef4a 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutor.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/execution/FlinkExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.execution;
 
 import org.apache.flink.api.java.ExecutionEnvironment;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CartesianMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CartesianMapping.java
index f654008..08f4927 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CartesianMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CartesianMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CoGroupMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CoGroupMapping.java
index 5fc4740..b2e79a2 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CoGroupMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CoGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CollectionSourceMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CollectionSourceMapping.java
index ad4a7a1..289207f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CollectionSourceMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CollectionSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CountMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CountMapping.java
index 32bfa66..95e9975 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CountMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/CountMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.CountOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DistinctMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DistinctMapping.java
index 790f3e4..adf2481 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DistinctMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DistinctMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.DistinctOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DoWhileMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DoWhileMapping.java
index 7c0593d..d4fc663 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DoWhileMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/DoWhileMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.DoWhileOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FilterMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FilterMapping.java
index 5f147f5..8afea3b 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FilterMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FilterMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.FilterOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FlatMapMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FlatMapMapping.java
index 059a406..2a898ed 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FlatMapMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/FlatMapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.FlatMapOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalMaterializedGroupMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalMaterializedGroupMapping.java
index 487120e..870e1aa 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalMaterializedGroupMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalMaterializedGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalReduceMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalReduceMapping.java
index 0b8f73e..7ced46d 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalReduceMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GlobalReduceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.GlobalReduceOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GroupByMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GroupByMapping.java
index 46cf397..9c9faa0 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GroupByMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/GroupByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.GroupByOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/IntersectMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/IntersectMapping.java
index c996368..368a040 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/IntersectMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/IntersectMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.IntersectOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/JoinMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/JoinMapping.java
index cd8a465..cc98c82 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/JoinMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/JoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.JoinOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LocalCallbackSinkMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LocalCallbackSinkMapping.java
index 1cdeb53..586c309 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LocalCallbackSinkMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LocalCallbackSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.LocalCallbackSink;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LoopMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LoopMapping.java
index 196411e..dab0374 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LoopMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/LoopMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.LoopOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapMapping.java
index 11d7175..dbbe5e2 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.MapOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapPartitionsMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapPartitionsMapping.java
index d4360f2..bc2a1e2 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapPartitionsMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MapPartitionsMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.MapPartitionsOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/Mappings.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/Mappings.java
index 3b328d5..2406544 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/Mappings.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MaterializedGroupByMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MaterializedGroupByMapping.java
index bceae2e..8fa46c1 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MaterializedGroupByMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/MaterializedGroupByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.MaterializedGroupByOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/PageRankMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/PageRankMapping.java
index 8ebded1..b35a600 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/PageRankMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.PageRankOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ReduceByMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ReduceByMapping.java
index be6a184..8d5d666 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ReduceByMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ReduceByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.ReduceByOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/RepeatMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/RepeatMapping.java
index 19b0a4e..5de4d4a 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/RepeatMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/RepeatMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.RepeatOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SampleMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SampleMapping.java
index b07a21d..f1d3feb 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SampleMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SampleMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.SampleOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SortMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SortMapping.java
index 1833201..412803f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SortMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/SortMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.SortOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSinkMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSinkMapping.java
index 8a30530..c5963fb 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSinkMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.TextFileSink;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSourceMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSourceMapping.java
index dc736ab..a57bb66 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSourceMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/TextFileSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.TextFileSource;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/UnionAllMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/UnionAllMapping.java
index 0095580..ec2f0ed 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/UnionAllMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/UnionAllMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.UnionAllOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ZipWithIdMapping.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ZipWithIdMapping.java
index eca7ec2..c45de87 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ZipWithIdMapping.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/mapping/ZipWithIdMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.mapping;
 
 import org.apache.wayang.basic.operators.ZipWithIdOperator;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCartesianOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCartesianOperator.java
index e65dc61..280586b 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCartesianOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCartesianOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCoGroupOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCoGroupOperator.java
index d8b6301..d1230b7 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCoGroupOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCoGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.CoGroupFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSink.java
index 8fb450d..c88f656 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSource.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSource.java
index c833eec..577f67f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSource.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCollectionSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCountOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCountOperator.java
index dcd9a48..570e97e 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCountOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkCountOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDistinctOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDistinctOperator.java
index 874faa2..72037be 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDistinctOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDistinctOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDoWhileOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDoWhileOperator.java
index 609fa80..a558e1d 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDoWhileOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkDoWhileOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.aggregators.ConvergenceCriterion;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkExecutionOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkExecutionOperator.java
index 96cec2a..f8b5da4 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkExecutionOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFilterOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFilterOperator.java
index 9076d1b..9954f7f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFilterOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.FilterFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFlatMapOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFlatMapOperator.java
index 460a6ec..d2f8c41 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFlatMapOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkFlatMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.FlatMapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalMaterializedGroupOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalMaterializedGroupOperator.java
index 8de2ceb..a2c78f7 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalMaterializedGroupOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalMaterializedGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.MapPartitionFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalReduceOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalReduceOperator.java
index c1fd393..a5ccec3 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalReduceOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGlobalReduceOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.ReduceFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGroupByOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGroupByOperator.java
index 4c98f98..b2f236f 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGroupByOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkGroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.GroupReduceFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkIntersectOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkIntersectOperator.java
index 8654c25..2e4d518 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkIntersectOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkIntersectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.MapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkJoinOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkJoinOperator.java
index e5aa807..f60b578 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkJoinOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.JoinFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLocalCallbackSink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLocalCallbackSink.java
index 57839db..c3a8e6e 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLocalCallbackSink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLocalCallbackSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLoopOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLoopOperator.java
index 6f3a91e..826c187 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLoopOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkLoopOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.aggregators.ConvergenceCriterion;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapOperator.java
index 41c96d9..57f7b96 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.MapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapPartitionsOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapPartitionsOperator.java
index 1ae51f5..215c473 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapPartitionsOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMapPartitionsOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.MapPartitionFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMaterializedGroupByOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMaterializedGroupByOperator.java
index 48c9df5..627259a 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMaterializedGroupByOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkMaterializedGroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.GroupReduceFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSink.java
index b48191f..9130a97 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.operators.DataSink;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSource.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSource.java
index 47c840a..fb1e569 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSource.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkObjectFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.FlatMapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkPageRankOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkPageRankOperator.java
index b913a71..6a62337 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkPageRankOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkPageRankOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.FilterFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkReduceByOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkReduceByOperator.java
index 9c099a7..d0d7e03 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkReduceByOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkReduceByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.ReduceFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatExpandedOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatExpandedOperator.java
index 47d0100..b60abe2 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatExpandedOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatExpandedOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatOperator.java
index 4c51281..3b5507c 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkRepeatOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSampleOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSampleOperator.java
index 71258fd..86b0613 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSampleOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSortOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSortOperator.java
index 5096797..97e5d19 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSortOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkSortOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.operators.Order;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSink.java
index 74186dc..9682344 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSource.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSource.java
index 10e3aee..2485acf 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSource.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTextFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTsvFileSink.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTsvFileSink.java
index 4af5726..4bc2ba9 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTsvFileSink.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkTsvFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.common.functions.MapFunction;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkUnionAllOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkUnionAllOperator.java
index bb8841c..93452ff 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkUnionAllOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkUnionAllOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkZipWithIdOperator.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkZipWithIdOperator.java
index 9213f57..027821a 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkZipWithIdOperator.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/operators/FlinkZipWithIdOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.operators;
 
 import org.apache.flink.api.java.DataSet;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/platform/FlinkPlatform.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/platform/FlinkPlatform.java
index 6df408e..da3b510 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/platform/FlinkPlatform.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/platform/FlinkPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.platform;
 
 import org.apache.flink.api.java.CollectionEnvironment;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkBasicPlugin.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkBasicPlugin.java
index 496c30f..bc7df27 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkBasicPlugin.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkBasicPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkConversionPlugin.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkConversionPlugin.java
index 04f57a8..eb4a8c8 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkConversionPlugin.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkConversionPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkGraphPlugin.java b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkGraphPlugin.java
index cabe39d..e563900 100644
--- a/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkGraphPlugin.java
+++ b/wayang-platforms/wayang-flink/src/main/java/org/apache/wayang/flink/plugin/FlinkGraphPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.flink.plugin;
 
 import org.apache.wayang.core.plan.wayangplan.Operator;


[incubator-wayang] 10/16: Add header licence to files in wayang-java

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 4d19faabee51d90305f184ff808ed1c2687a9adc
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:21:14 2021 -0300

    Add header licence to files in wayang-java
---
 wayang-platforms/wayang-java/pom.xml                   | 11 +++++++++++
 .../src/main/java/org/apache/wayang/java/Java.java     | 18 ++++++++++++++++++
 .../wayang/java/channels/ChannelConversions.java       | 18 ++++++++++++++++++
 .../apache/wayang/java/channels/CollectionChannel.java | 18 ++++++++++++++++++
 .../wayang/java/channels/JavaChannelInstance.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/java/channels/StreamChannel.java | 18 ++++++++++++++++++
 .../apache/wayang/java/compiler/FunctionCompiler.java  | 18 ++++++++++++++++++
 .../wayang/java/execution/JavaExecutionContext.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/execution/JavaExecutor.java | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/CartesianMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/CoGroupMapping.java | 18 ++++++++++++++++++
 .../wayang/java/mapping/CollectionSourceMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/CountMapping.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/DistinctMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/DoWhileMapping.java | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/FilterMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/FlatMapMapping.java | 18 ++++++++++++++++++
 .../java/mapping/GlobalMaterializedGroupMapping.java   | 18 ++++++++++++++++++
 .../wayang/java/mapping/GlobalReduceMapping.java       | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/IntersectMapping.java   | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/JoinMapping.java    | 18 ++++++++++++++++++
 .../wayang/java/mapping/LocalCallbackSinkMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/LoopMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/MapMapping.java     | 18 ++++++++++++++++++
 .../wayang/java/mapping/MapPartitionsMapping.java      | 18 ++++++++++++++++++
 .../java/org/apache/wayang/java/mapping/Mappings.java  | 18 ++++++++++++++++++
 .../java/mapping/MaterializedGroupByMapping.java       | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/ReduceByMapping.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/RepeatMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/SampleMapping.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/mapping/SortMapping.java    | 18 ++++++++++++++++++
 .../wayang/java/mapping/TextFileSinkMapping.java       | 18 ++++++++++++++++++
 .../wayang/java/mapping/TextFileSourceMapping.java     | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/UnionAllMapping.java    | 18 ++++++++++++++++++
 .../apache/wayang/java/mapping/ZipWithIdMapping.java   | 18 ++++++++++++++++++
 .../wayang/java/mapping/graph/PageRankMapping.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCartesianOperator.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCoGroupOperator.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCollectOperator.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCollectionSource.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCountOperator.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaDistinctOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaDoWhileOperator.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaExecutionOperator.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFilterOperator.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFlatMapOperator.java     | 18 ++++++++++++++++++
 .../operators/JavaGlobalMaterializedGroupOperator.java | 18 ++++++++++++++++++
 .../java/operators/JavaGlobalReduceOperator.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaIntersectOperator.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaJoinOperator.java | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaLocalCallbackSink.java   | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaLoopOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaMapOperator.java  | 18 ++++++++++++++++++
 .../java/operators/JavaMapPartitionsOperator.java      | 18 ++++++++++++++++++
 .../operators/JavaMaterializedGroupByOperator.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSink.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSource.java    | 18 ++++++++++++++++++
 .../java/operators/JavaRandomSampleOperator.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaReduceByOperator.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaRepeatOperator.java      | 18 ++++++++++++++++++
 .../java/operators/JavaReservoirSampleOperator.java    | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaSortOperator.java | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaTextFileSink.java | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTextFileSource.java      | 18 ++++++++++++++++++
 .../apache/wayang/java/operators/JavaTsvFileSink.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTsvFileSource.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaUnionAllOperator.java    | 18 ++++++++++++++++++
 .../java/operators/graph/JavaPageRankOperator.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/java/platform/JavaPlatform.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/java/plugin/JavaBasicPlugin.java | 18 ++++++++++++++++++
 .../java/plugin/JavaChannelConversionPlugin.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/java/plugin/JavaGraphPlugin.java | 18 ++++++++++++++++++
 .../apache/wayang/java/execution/JavaExecutorTest.java | 18 ++++++++++++++++++
 .../java/operators/JavaCartesianOperatorTest.java      | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCoGroupOperatorTest.java | 18 ++++++++++++++++++
 .../java/operators/JavaCollectionSourceTest.java       | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaCountOperatorTest.java   | 18 ++++++++++++++++++
 .../java/operators/JavaDistinctOperatorTest.java       | 18 ++++++++++++++++++
 .../java/operators/JavaExecutionOperatorTestBase.java  | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaFilterOperatorTest.java  | 18 ++++++++++++++++++
 .../JavaGlobalMaterializedGroupOperatorTest.java       | 18 ++++++++++++++++++
 .../java/operators/JavaGlobalReduceOperatorTest.java   | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaJoinOperatorTest.java    | 18 ++++++++++++++++++
 .../java/operators/JavaLocalCallbackSinkTest.java      | 18 ++++++++++++++++++
 .../operators/JavaMaterializedGroupByOperatorTest.java | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaObjectFileSinkTest.java  | 18 ++++++++++++++++++
 .../java/operators/JavaObjectFileSourceTest.java       | 18 ++++++++++++++++++
 .../java/operators/JavaRandomSampleOperatorTest.java   | 18 ++++++++++++++++++
 .../java/operators/JavaReduceByOperatorTest.java       | 18 ++++++++++++++++++
 .../operators/JavaReservoirSampleOperatorTest.java     | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaSortOperatorTest.java    | 18 ++++++++++++++++++
 .../wayang/java/operators/JavaTextFileSinkTest.java    | 18 ++++++++++++++++++
 .../java/operators/JavaUnionAllOperatorTest.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/java/test/ChannelFactory.java    | 18 ++++++++++++++++++
 94 files changed, 1685 insertions(+)

diff --git a/wayang-platforms/wayang-java/pom.xml b/wayang-platforms/wayang-java/pom.xml
index c290ce0..3593c98 100644
--- a/wayang-platforms/wayang-java/pom.xml
+++ b/wayang-platforms/wayang-java/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/Java.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/Java.java
index 4a58381..543cc63 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/Java.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/Java.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java;
 
 import org.apache.wayang.java.platform.JavaPlatform;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/ChannelConversions.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/ChannelConversions.java
index 18c60f4..e1e9661 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.channels;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/CollectionChannel.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/CollectionChannel.java
index 0d20422..c71c840 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/CollectionChannel.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/CollectionChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.channels;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/JavaChannelInstance.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/JavaChannelInstance.java
index a9a132a..dbcdf8d 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/JavaChannelInstance.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/JavaChannelInstance.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.channels;
 
 import org.apache.wayang.core.plan.executionplan.Channel;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/StreamChannel.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/StreamChannel.java
index dec0ea3..98d8a89 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/StreamChannel.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/channels/StreamChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.channels;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/compiler/FunctionCompiler.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/compiler/FunctionCompiler.java
index 7003ee8..32c3bcb 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/compiler/FunctionCompiler.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/compiler/FunctionCompiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.compiler;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutionContext.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutionContext.java
index 59bf7d0..14b46cc 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutionContext.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutionContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.execution;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutor.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutor.java
index 00344fa..6150b7c 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutor.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/execution/JavaExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.execution;
 
 import org.apache.wayang.core.api.Job;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CartesianMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CartesianMapping.java
index e79e8ce..9fca8af 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CartesianMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CartesianMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.CartesianOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CoGroupMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CoGroupMapping.java
index f016de6..d029d7c 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CoGroupMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CoGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.CoGroupOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CollectionSourceMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CollectionSourceMapping.java
index 78f1369..d56087b 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CollectionSourceMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CollectionSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CountMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CountMapping.java
index f43c693..ec2c97a 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CountMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/CountMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.CountOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DistinctMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DistinctMapping.java
index f6c51fc..bdea8d7 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DistinctMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DistinctMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.DistinctOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DoWhileMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DoWhileMapping.java
index 7f42d0d..c71fab6 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DoWhileMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/DoWhileMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.DoWhileOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FilterMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FilterMapping.java
index ef8286c..a75c4cb 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FilterMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FilterMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.FilterOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FlatMapMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FlatMapMapping.java
index 8a6561b..3f282c0 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FlatMapMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/FlatMapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.FlatMapOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalMaterializedGroupMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalMaterializedGroupMapping.java
index 9b8cfb3..7472966 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalMaterializedGroupMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalMaterializedGroupMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalReduceMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalReduceMapping.java
index a18cf8a..c4aa625 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalReduceMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/GlobalReduceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.GlobalReduceOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/IntersectMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/IntersectMapping.java
index 0254611..c3e1750 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/IntersectMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/IntersectMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.IntersectOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/JoinMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/JoinMapping.java
index 87a2c0e..e48d0eb 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/JoinMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/JoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.JoinOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LocalCallbackSinkMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LocalCallbackSinkMapping.java
index 42c4119..51b7819 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LocalCallbackSinkMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LocalCallbackSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.LocalCallbackSink;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LoopMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LoopMapping.java
index 66a4737..de3386d 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LoopMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/LoopMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.LoopOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapMapping.java
index 35d7f11..60c73cb 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.MapOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapPartitionsMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapPartitionsMapping.java
index 1b9644e..dc1bb5a 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapPartitionsMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MapPartitionsMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.MapPartitionsOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/Mappings.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/Mappings.java
index d80aef1..ee9cebc 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/Mappings.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MaterializedGroupByMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MaterializedGroupByMapping.java
index f94d7d1..b74e5e0 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MaterializedGroupByMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/MaterializedGroupByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.MaterializedGroupByOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ReduceByMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ReduceByMapping.java
index 09364f4..cea8d88 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ReduceByMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ReduceByMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.ReduceByOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/RepeatMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/RepeatMapping.java
index 5c964da..8d80f33 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/RepeatMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/RepeatMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.RepeatOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SampleMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SampleMapping.java
index 8a16a4c..6cf42c2 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SampleMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SampleMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.SampleOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SortMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SortMapping.java
index ff0323d..302f118 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SortMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/SortMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.SortOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSinkMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSinkMapping.java
index db818fe..eb1d05a 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSinkMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSinkMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.TextFileSink;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSourceMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSourceMapping.java
index c709eef..3bc5aa1 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSourceMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/TextFileSourceMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.TextFileSource;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/UnionAllMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/UnionAllMapping.java
index 5a18005..8fc0fbf 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/UnionAllMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/UnionAllMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.operators.UnionAllOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ZipWithIdMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ZipWithIdMapping.java
index 23c61fe..ce0f590 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ZipWithIdMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/ZipWithIdMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/graph/PageRankMapping.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/graph/PageRankMapping.java
index b48972f..d2a4c3d 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/graph/PageRankMapping.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/mapping/graph/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.mapping.graph;
 
 import org.apache.wayang.basic.operators.PageRankOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCartesianOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCartesianOperator.java
index 0aa51a8..cdb4822 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCartesianOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCartesianOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCoGroupOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCoGroupOperator.java
index e007e83..253110f 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCoGroupOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCoGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectOperator.java
index 781b7d0..10ddfa6 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectionSource.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectionSource.java
index 123e8e2..7020349 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectionSource.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCollectionSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.CollectionSource;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCountOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCountOperator.java
index 81d562c..0cdf1fd 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCountOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaCountOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.CountOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDistinctOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDistinctOperator.java
index 222967b..2f43c83 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDistinctOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDistinctOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.DistinctOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDoWhileOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDoWhileOperator.java
index f79fcf3..d1a3659 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDoWhileOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaDoWhileOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.DoWhileOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaExecutionOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaExecutionOperator.java
index 574b097..d6b2ae3 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaExecutionOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFilterOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFilterOperator.java
index da54dfd..757220e 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFilterOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.FilterOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFlatMapOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFlatMapOperator.java
index 26436d4..3c101ad 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFlatMapOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaFlatMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.FlatMapOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperator.java
index c0da57e..1fffb1d 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.GlobalMaterializedGroupOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalReduceOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalReduceOperator.java
index 2d07368..afe5e7e 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalReduceOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaGlobalReduceOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.GlobalReduceOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaIntersectOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaIntersectOperator.java
index ef61063..1019b4b 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaIntersectOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaIntersectOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.IntersectOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaJoinOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaJoinOperator.java
index 3ddf566..7bd0f36 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaJoinOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLocalCallbackSink.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLocalCallbackSink.java
index 9608a98..8e99e18 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLocalCallbackSink.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLocalCallbackSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.LocalCallbackSink;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLoopOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLoopOperator.java
index 4626436..5cd4e93 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLoopOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaLoopOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.LoopOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapOperator.java
index 1e4f3ca..62fe702 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.MapOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapPartitionsOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapPartitionsOperator.java
index 4adb366..5a6ebc2 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapPartitionsOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMapPartitionsOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.MapPartitionsOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperator.java
index abe2d05..e4aae19 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.MaterializedGroupByOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSink.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSink.java
index d4f7cac..50cd525 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSink.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.io.output.ByteArrayOutputStream;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSource.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSource.java
index f738663..24fedd5 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSource.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaObjectFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRandomSampleOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRandomSampleOperator.java
index 3cd3b93..528f716 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRandomSampleOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRandomSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.SampleOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReduceByOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReduceByOperator.java
index f1f1b83..6721a6a 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReduceByOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReduceByOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.ReduceByOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRepeatOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRepeatOperator.java
index d81f0ca..048f7d2 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRepeatOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaRepeatOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.DoWhileOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReservoirSampleOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReservoirSampleOperator.java
index 531f3a9..f6946e6 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReservoirSampleOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaReservoirSampleOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.SampleOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaSortOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaSortOperator.java
index e7b348a..587c0a3 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaSortOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaSortOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.SortOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSink.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSink.java
index d34d715..bd7cdcf 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSink.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.TextFileSink;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSource.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSource.java
index 501444b..6d8577f 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSource.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTextFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.TextFileSource;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSink.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSink.java
index 412929d..61a197c 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSink.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSink.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSource.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSource.java
index fc52a79..2580032 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSource.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaTsvFileSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.io.IOUtils;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaUnionAllOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaUnionAllOperator.java
index d2cb4b0..61cad25 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaUnionAllOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/JavaUnionAllOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.wayang.basic.operators.UnionAllOperator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/graph/JavaPageRankOperator.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/graph/JavaPageRankOperator.java
index 30bff8f..e4633a5 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/graph/JavaPageRankOperator.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/operators/graph/JavaPageRankOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators.graph;
 
 import gnu.trove.iterator.TLongFloatIterator;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/platform/JavaPlatform.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/platform/JavaPlatform.java
index 63989a4..0628428 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/platform/JavaPlatform.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/platform/JavaPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.platform;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaBasicPlugin.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaBasicPlugin.java
index 4dd881f..4771401 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaBasicPlugin.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaBasicPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaChannelConversionPlugin.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaChannelConversionPlugin.java
index 6116e33..346b541 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaChannelConversionPlugin.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaChannelConversionPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaGraphPlugin.java b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaGraphPlugin.java
index d33203d..f581cac 100644
--- a/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaGraphPlugin.java
+++ b/wayang-platforms/wayang-java/src/main/java/org/apache/wayang/java/plugin/JavaGraphPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/execution/JavaExecutorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/execution/JavaExecutorTest.java
index ffb1b76..39f76f4 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/execution/JavaExecutorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/execution/JavaExecutorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.execution;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCartesianOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCartesianOperatorTest.java
index fd4ce03..05c8e7f 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCartesianOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCartesianOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCoGroupOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCoGroupOperatorTest.java
index 1974317..64b7451 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCoGroupOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCoGroupOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCollectionSourceTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCollectionSourceTest.java
index b6aadf6..4446430 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCollectionSourceTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCollectionSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCountOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCountOperatorTest.java
index d6467b8..a7af4ad 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCountOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaCountOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaDistinctOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaDistinctOperatorTest.java
index f7b90e7..6c9632b 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaDistinctOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaDistinctOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaExecutionOperatorTestBase.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaExecutionOperatorTestBase.java
index 40aec52..67c7ab4 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaExecutionOperatorTestBase.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaExecutionOperatorTestBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.BeforeClass;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaFilterOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaFilterOperatorTest.java
index 9dd8201..504d9c9 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaFilterOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaFilterOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperatorTest.java
index 66c3247..b63b623 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalMaterializedGroupOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalReduceOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalReduceOperatorTest.java
index c402bd0..54023f1 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalReduceOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaGlobalReduceOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaJoinOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaJoinOperatorTest.java
index 1dacae3..65cb5f7 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaJoinOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaJoinOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaLocalCallbackSinkTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaLocalCallbackSinkTest.java
index 8800ef2..fd23e49 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaLocalCallbackSinkTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaLocalCallbackSinkTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperatorTest.java
index f87e42f..4aa76d6 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaMaterializedGroupByOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSinkTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSinkTest.java
index 8215715..781d256 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSinkTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSinkTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSourceTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSourceTest.java
index 104580b..0a3d9d6 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSourceTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaObjectFileSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaRandomSampleOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaRandomSampleOperatorTest.java
index f565863..d8e9cd0 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaRandomSampleOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaRandomSampleOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReduceByOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReduceByOperatorTest.java
index 924b08e..225f397 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReduceByOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReduceByOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReservoirSampleOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReservoirSampleOperatorTest.java
index 3be4855..66d56a5 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReservoirSampleOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaReservoirSampleOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaSortOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaSortOperatorTest.java
index 032fd5b..3483ab5 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaSortOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaSortOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaTextFileSinkTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaTextFileSinkTest.java
index 9d0efc9..9248bcf 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaTextFileSinkTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaTextFileSinkTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaUnionAllOperatorTest.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaUnionAllOperatorTest.java
index 9ccfde1..7f61545 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaUnionAllOperatorTest.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/operators/JavaUnionAllOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/test/ChannelFactory.java b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/test/ChannelFactory.java
index 2bdbaca..87ee278 100644
--- a/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/test/ChannelFactory.java
+++ b/wayang-platforms/wayang-java/src/test/java/org/apache/wayang/java/test/ChannelFactory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.java.test;
 
 import org.junit.Before;


[incubator-wayang] 01/16: Add DISCLAIMER

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 8689cc11903b31cb0dbf30a1f01fdeb73124a508
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 13:48:44 2021 -0300

    Add DISCLAIMER
---
 DISCLAIMER | 7 +++++++
 1 file changed, 7 insertions(+)

diff --git a/DISCLAIMER b/DISCLAIMER
new file mode 100644
index 0000000..9ebfb65
--- /dev/null
+++ b/DISCLAIMER
@@ -0,0 +1,7 @@
+Apache Wayang is an effort undergoing incubation at The Apache Software
+Foundation (ASF), sponsored by the Apache Incubator PMC. Incubation is required
+of all newly accepted projects until a further review indicates that the
+infrastructure, communications, and decision making process have stabilized in
+a manner consistent with other successful ASF projects. While incubation status
+is not necessarily a reflection of the completeness or stability of the code,
+it does indicate that the project has yet to be fully endorsed by the ASF.
\ No newline at end of file


[incubator-wayang] 12/16: Add header licence to files in wayang-jdbc-template

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 7e1808f707451593a7b0d29e691256e730019229
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:22:57 2021 -0300

    Add header licence to files in wayang-jdbc-template
---
 wayang-platforms/wayang-jdbc-template/pom.xml          | 11 +++++++++++
 .../apache/wayang/jdbc/channels/SqlQueryChannel.java   | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/compiler/FunctionCompiler.java  | 18 ++++++++++++++++++
 .../wayang/jdbc/execution/DatabaseDescriptor.java      | 18 ++++++++++++++++++
 .../org/apache/wayang/jdbc/execution/JdbcExecutor.java | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcExecutionOperator.java   | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcFilterOperator.java      | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcProjectionOperator.java  | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/operators/JdbcTableSource.java  | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/SqlToStreamOperator.java     | 18 ++++++++++++++++++
 .../wayang/jdbc/platform/JdbcPlatformTemplate.java     | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/execution/JdbcExecutorTest.java | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/JdbcTableSourceTest.java     | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/operators/OperatorTestBase.java | 18 ++++++++++++++++++
 .../wayang/jdbc/operators/SqlToStreamOperatorTest.java | 18 ++++++++++++++++++
 .../apache/wayang/jdbc/test/HsqldbFilterOperator.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/jdbc/test/HsqldbPlatform.java    | 18 ++++++++++++++++++
 .../wayang/jdbc/test/HsqldbProjectionOperator.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/jdbc/test/HsqldbTableSource.java | 18 ++++++++++++++++++
 19 files changed, 335 insertions(+)

diff --git a/wayang-platforms/wayang-jdbc-template/pom.xml b/wayang-platforms/wayang-jdbc-template/pom.xml
index 596252c..9086b94 100644
--- a/wayang-platforms/wayang-jdbc-template/pom.xml
+++ b/wayang-platforms/wayang-jdbc-template/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/channels/SqlQueryChannel.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/channels/SqlQueryChannel.java
index bc4f1c6..f0dae79 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/channels/SqlQueryChannel.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/channels/SqlQueryChannel.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.channels;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/compiler/FunctionCompiler.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/compiler/FunctionCompiler.java
index e2ba39f..01cc433 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/compiler/FunctionCompiler.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/compiler/FunctionCompiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.compiler;
 
 import org.apache.wayang.core.function.FunctionDescriptor;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/DatabaseDescriptor.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/DatabaseDescriptor.java
index f31d1b8..0aeb475 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/DatabaseDescriptor.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/DatabaseDescriptor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.execution;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/JdbcExecutor.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/JdbcExecutor.java
index 2f724ca..f374991 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/JdbcExecutor.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/execution/JdbcExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.execution;
 
 import org.apache.wayang.basic.channels.FileChannel;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcExecutionOperator.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcExecutionOperator.java
index 0be5a3f..f6ccccf 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcExecutionOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.apache.wayang.basic.operators.TableSource;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcFilterOperator.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcFilterOperator.java
index 3ad0eb5..d28253a 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcFilterOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcProjectionOperator.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcProjectionOperator.java
index 018421d..c8615fa 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcProjectionOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcProjectionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcTableSource.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcTableSource.java
index 3d01c92..55b4bb7 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcTableSource.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/JdbcTableSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import de.hpi.isg.profiledb.store.model.TimeMeasurement;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/SqlToStreamOperator.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/SqlToStreamOperator.java
index 7be5599..c816dea 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/SqlToStreamOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/operators/SqlToStreamOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.json.JSONObject;
diff --git a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/platform/JdbcPlatformTemplate.java b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/platform/JdbcPlatformTemplate.java
index db7306f..a5d7709 100644
--- a/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/platform/JdbcPlatformTemplate.java
+++ b/wayang-platforms/wayang-jdbc-template/src/main/java/org/apache/wayang/jdbc/platform/JdbcPlatformTemplate.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.platform;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/execution/JdbcExecutorTest.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/execution/JdbcExecutorTest.java
index b90a78c..0a6e952 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/execution/JdbcExecutorTest.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/execution/JdbcExecutorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.execution;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/JdbcTableSourceTest.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/JdbcTableSourceTest.java
index 9754894..3feb5c7 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/JdbcTableSourceTest.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/JdbcTableSourceTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import de.hpi.isg.profiledb.instrumentation.StopWatch;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/OperatorTestBase.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/OperatorTestBase.java
index 46755bd..eda04e5 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/OperatorTestBase.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/OperatorTestBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.junit.BeforeClass;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/SqlToStreamOperatorTest.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/SqlToStreamOperatorTest.java
index 2cb5ff0..affd236 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/SqlToStreamOperatorTest.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/operators/SqlToStreamOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.operators;
 
 import org.junit.Assert;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbFilterOperator.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbFilterOperator.java
index d5bea5f..2878f2a 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbFilterOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbFilterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.test;
 
 import org.apache.wayang.core.function.PredicateDescriptor;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbPlatform.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbPlatform.java
index cef4008..c83338d 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbPlatform.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.test;
 
 import org.apache.wayang.jdbc.platform.JdbcPlatformTemplate;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbProjectionOperator.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbProjectionOperator.java
index 0faa74e..3f7bc7e 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbProjectionOperator.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbProjectionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.test;
 
 import org.apache.wayang.core.platform.ChannelDescriptor;
diff --git a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbTableSource.java b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbTableSource.java
index a1b4093..72f9fe5 100644
--- a/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbTableSource.java
+++ b/wayang-platforms/wayang-jdbc-template/src/test/java/org/apache/wayang/jdbc/test/HsqldbTableSource.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.jdbc.test;
 
 import org.apache.wayang.basic.operators.TableSource;


[incubator-wayang] 06/16: Add header licence to files in wayang-extensions

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit a5aa26f1b1c71e37f68ae575d2525e38856a0df5
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:17:04 2021 -0300

    Add header licence to files in wayang-extensions
---
 wayang-extensions/pom.xml                              | 11 +++++++++++
 wayang-extensions/wayang-iejoin/pom.xml                | 11 +++++++++++
 .../src/main/java/org/apache/wayang/iejoin/IEJoin.java | 18 ++++++++++++++++++
 .../main/java/org/apache/wayang/iejoin/data/Data.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/iejoin/mapping/Mappings.java     | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/java/IEJoinMapping.java      | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/java/IESelfJoinMapping.java  | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/spark/IEJoinMapping.java     | 18 ++++++++++++++++++
 .../wayang/iejoin/mapping/spark/IESelfJoinMapping.java | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/IEJoinMasterOperator.java  | 18 ++++++++++++++++++
 .../apache/wayang/iejoin/operators/IEJoinOperator.java | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/IESelfJoinOperator.java    | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/JavaIEJoinOperator.java    | 18 ++++++++++++++++++
 .../iejoin/operators/JavaIESelfJoinOperator.java       | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/SparkIEJoinOperator.java   | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIESelfJoinOperator.java      | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/BitSetJoin.java      | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/DataComparator.java  | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/extractData.java     | 18 ++++++++++++++++++
 .../iejoin/operators/java_helpers/myMergeSort.java     | 18 ++++++++++++++++++
 .../operators/java_helpers/revDataComparator.java      | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/BitSetJoin.java     | 18 ++++++++++++++++++
 .../spark_helpers/List2AttributesObjectSkinny.java     | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/addUniqueID.java    | 18 ++++++++++++++++++
 .../operators/spark_helpers/build2ListObject.java      | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/extractData.java    | 18 ++++++++++++++++++
 .../operators/spark_helpers/filterUnwantedBlocks.java  | 18 ++++++++++++++++++
 .../iejoin/operators/spark_helpers/myMergeSort.java    | 18 ++++++++++++++++++
 .../operators/spark_helpers/revDataComparator.java     | 18 ++++++++++++++++++
 .../operators/JavaExecutionOperatorTestBase.java       | 18 ++++++++++++++++++
 .../iejoin/operators/JavaIEJoinOperatorTest.java       | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest.java      | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest2.java     | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest3.java     | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIEJoinOperatorTest4.java     | 18 ++++++++++++++++++
 .../iejoin/operators/SparkIESelfJoinOperatorTest.java  | 18 ++++++++++++++++++
 .../wayang/iejoin/operators/SparkOperatorTestBase.java | 18 ++++++++++++++++++
 .../org/apache/wayang/iejoin/test/ChannelFactory.java  | 18 ++++++++++++++++++
 38 files changed, 670 insertions(+)

diff --git a/wayang-extensions/pom.xml b/wayang-extensions/pom.xml
index a8697ae..a6f6fdb 100644
--- a/wayang-extensions/pom.xml
+++ b/wayang-extensions/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-extensions/wayang-iejoin/pom.xml b/wayang-extensions/wayang-iejoin/pom.xml
index 5291ce4..231638d 100644
--- a/wayang-extensions/wayang-iejoin/pom.xml
+++ b/wayang-extensions/wayang-iejoin/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-extensions</artifactId>
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/IEJoin.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/IEJoin.java
index 0f9dd87..4ea2ee2 100644
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/IEJoin.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/IEJoin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/data/Data.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/data/Data.java
index 1698645..e5520f6 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/data/Data.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/data/Data.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.data;
 
 import java.io.Serializable;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/Mappings.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/Mappings.java
index deba94b..0257599 100644
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/Mappings.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.mapping;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IEJoinMapping.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IEJoinMapping.java
index c0753b3..4e2791f 100644
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IEJoinMapping.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IEJoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.mapping.java;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IESelfJoinMapping.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IESelfJoinMapping.java
index 58bb8b9..6f4a719 100644
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IESelfJoinMapping.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/java/IESelfJoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.mapping.java;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IEJoinMapping.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IEJoinMapping.java
index c506cc7..dd8546f 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IEJoinMapping.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IEJoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.mapping.spark;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IESelfJoinMapping.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IESelfJoinMapping.java
index 2c23996..923f3d9 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IESelfJoinMapping.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/mapping/spark/IESelfJoinMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.mapping.spark;
 
 import org.apache.wayang.basic.data.Record;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinMasterOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinMasterOperator.java
index 99a41ef..a84a1b7 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinMasterOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinMasterOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.wayang.basic.data.Tuple5;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinOperator.java
index cdd4aed..4e59025 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IEJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IESelfJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IESelfJoinOperator.java
index 34159bc..dd88be6 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IESelfJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/IESelfJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.wayang.basic.data.Tuple2;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperator.java
index 070bdc7..31a5aad 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.wayang.core.function.TransformationDescriptor;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIESelfJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIESelfJoinOperator.java
index ba80055..ca5d5fa 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIESelfJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/JavaIESelfJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.wayang.core.function.TransformationDescriptor;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperator.java
index 402e1c9..7b719a0 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperator.java
index 1c596a1..551a624 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.spark.api.java.JavaPairRDD;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/BitSetJoin.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/BitSetJoin.java
index d85ed6b..4c07294 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/BitSetJoin.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/BitSetJoin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.java_helpers;
 
 import org.apache.wayang.iejoin.data.Data;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/DataComparator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/DataComparator.java
index db0f1cb..b753c5a 100644
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/DataComparator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/DataComparator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.java_helpers;
 
 import org.apache.wayang.iejoin.data.Data;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/extractData.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/extractData.java
index 672b162..5db0056 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/extractData.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/extractData.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.java_helpers;
 
 
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/myMergeSort.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/myMergeSort.java
index 6c1ffac..6834e57 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/myMergeSort.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/myMergeSort.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.java_helpers;
 
 import org.apache.wayang.iejoin.data.Data;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/revDataComparator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/revDataComparator.java
index 633d556..7e3ed72 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/revDataComparator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/java_helpers/revDataComparator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.java_helpers;
 
 import org.apache.wayang.iejoin.data.Data;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/BitSetJoin.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/BitSetJoin.java
index 9a774ce..41e251c 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/BitSetJoin.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/BitSetJoin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.spark.api.java.function.PairFlatMapFunction;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/List2AttributesObjectSkinny.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/List2AttributesObjectSkinny.java
index 3dbdf6b..df3c0f0 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/List2AttributesObjectSkinny.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/List2AttributesObjectSkinny.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.wayang.iejoin.data.Data;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/addUniqueID.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/addUniqueID.java
index ab5afd8..8753b27 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/addUniqueID.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/addUniqueID.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.spark.api.java.function.Function2;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/build2ListObject.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/build2ListObject.java
index 33fa653..5faa693 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/build2ListObject.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/build2ListObject.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.spark.api.java.function.Function2;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/extractData.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/extractData.java
index 623c662..a08f7bb 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/extractData.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/extractData.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/filterUnwantedBlocks.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/filterUnwantedBlocks.java
index 09f56bb..fc4dd67 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/filterUnwantedBlocks.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/filterUnwantedBlocks.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 import org.apache.spark.api.java.function.Function;
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/myMergeSort.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/myMergeSort.java
index 6c2add4..72cd4ed 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/myMergeSort.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/myMergeSort.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 
diff --git a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/revDataComparator.java b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/revDataComparator.java
index 4dc7db8..e5f2fbc 100755
--- a/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/revDataComparator.java
+++ b/wayang-extensions/wayang-iejoin/src/main/java/org/apache/wayang/iejoin/operators/spark_helpers/revDataComparator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators.spark_helpers;
 
 
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaExecutionOperatorTestBase.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaExecutionOperatorTestBase.java
index 25bcb70..6266505 100644
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaExecutionOperatorTestBase.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaExecutionOperatorTestBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.BeforeClass;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperatorTest.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperatorTest.java
index 735defe..137084a 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperatorTest.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/JavaIEJoinOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest.java
index 4e1db78..503798a 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest2.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest2.java
index 599a733..5c63d86 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest2.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest2.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest3.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest3.java
index 84fde4f..2083d25 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest3.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest3.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest4.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest4.java
index 10114c3..9840b51 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest4.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIEJoinOperatorTest4.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperatorTest.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperatorTest.java
index b5bc04f..8029737 100755
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperatorTest.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkIESelfJoinOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.junit.Assert;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkOperatorTestBase.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkOperatorTestBase.java
index 9f81e6e..aa33376 100644
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkOperatorTestBase.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/operators/SparkOperatorTestBase.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.operators;
 
 import org.apache.spark.api.java.JavaSparkContext;
diff --git a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/test/ChannelFactory.java b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/test/ChannelFactory.java
index 884446e..424b78d 100644
--- a/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/test/ChannelFactory.java
+++ b/wayang-extensions/wayang-iejoin/src/test/java/org/apache/wayang/iejoin/test/ChannelFactory.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.iejoin.test;
 
 import org.junit.Before;


[incubator-wayang] 15/16: Add header licence to files in wayang-profiler

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit fe798bf3822e825858907490008e7f2dd946942b
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:26:18 2021 -0300

    Add header licence to files in wayang-profiler
---
 wayang-profiler/pom.xml                                | 11 +++++++++++
 .../apache/wayang/profiler/data/DataGenerators.java    | 18 ++++++++++++++++++
 .../apache/wayang/profiler/hardware/DiskProfiler.java  | 18 ++++++++++++++++++
 .../wayang/profiler/java/BinaryOperatorProfiler.java   | 18 ++++++++++++++++++
 .../profiler/java/JavaCollectionSourceProfiler.java    | 18 ++++++++++++++++++
 .../profiler/java/JavaTextFileSourceProfiler.java      | 18 ++++++++++++++++++
 .../apache/wayang/profiler/java/OperatorProfiler.java  | 18 ++++++++++++++++++
 .../apache/wayang/profiler/java/OperatorProfilers.java | 18 ++++++++++++++++++
 .../java/org/apache/wayang/profiler/java/Profiler.java | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/java/SinkProfiler.java  | 18 ++++++++++++++++++
 .../apache/wayang/profiler/java/SourceProfiler.java    | 18 ++++++++++++++++++
 .../wayang/profiler/java/UnaryOperatorProfiler.java    | 18 ++++++++++++++++++
 .../wayang/profiler/log/DynamicEstimationContext.java  | 18 ++++++++++++++++++
 .../wayang/profiler/log/DynamicLoadEstimator.java      | 18 ++++++++++++++++++
 .../profiler/log/DynamicLoadProfileEstimator.java      | 18 ++++++++++++++++++
 .../profiler/log/DynamicLoadProfileEstimators.java     | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/GeneticOptimizer.java   | 18 ++++++++++++++++++
 .../wayang/profiler/log/GeneticOptimizerApp.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/log/Individual.java     | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/log/LogEvaluator.java   | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/OptimizationSpace.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/profiler/log/Variable.java  | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/sampling/Battle.java    | 18 ++++++++++++++++++
 .../wayang/profiler/log/sampling/ReservoirSampler.java | 18 ++++++++++++++++++
 .../apache/wayang/profiler/log/sampling/Sampler.java   | 18 ++++++++++++++++++
 .../profiler/log/sampling/TournamentSampler.java       | 18 ++++++++++++++++++
 .../wayang/profiler/spark/BinaryOperatorProfiler.java  | 18 ++++++++++++++++++
 .../java/org/apache/wayang/profiler/spark/Main.java    | 18 ++++++++++++++++++
 .../wayang/profiler/spark/OperatorProfilers.java       | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/spark/SinkProfiler.java | 18 ++++++++++++++++++
 .../profiler/spark/SparkCollectionSourceProfiler.java  | 18 ++++++++++++++++++
 .../wayang/profiler/spark/SparkOperatorProfiler.java   | 18 ++++++++++++++++++
 .../wayang/profiler/spark/SparkSourceProfiler.java     | 18 ++++++++++++++++++
 .../profiler/spark/SparkTextFileSourceProfiler.java    | 18 ++++++++++++++++++
 .../profiler/spark/SparkUnaryOperatorProfiler.java     | 18 ++++++++++++++++++
 .../apache/wayang/profiler/util/ProfilingUtils.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/profiler/util/RrdAccessor.java   | 18 ++++++++++++++++++
 37 files changed, 659 insertions(+)

diff --git a/wayang-profiler/pom.xml b/wayang-profiler/pom.xml
index f28626a..363e19a 100644
--- a/wayang-profiler/pom.xml
+++ b/wayang-profiler/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang</artifactId>
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/data/DataGenerators.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/data/DataGenerators.java
index 0accbf4..034f5ad 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/data/DataGenerators.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/data/DataGenerators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.data;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/hardware/DiskProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/hardware/DiskProfiler.java
index 1664176..f72b37d 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/hardware/DiskProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/hardware/DiskProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.hardware;
 
 import org.apache.commons.lang.Validate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/BinaryOperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/BinaryOperatorProfiler.java
index 3fbef2b..c873cb6 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/BinaryOperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/BinaryOperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.wayang.core.plan.wayangplan.InputSlot;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaCollectionSourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaCollectionSourceProfiler.java
index cc88c65..c8506fb 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaCollectionSourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaCollectionSourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.wayang.core.types.DataSetType;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaTextFileSourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaTextFileSourceProfiler.java
index a0c7695..0a73a8c 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaTextFileSourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/JavaTextFileSourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.wayang.java.operators.JavaTextFileSource;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfiler.java
index 643aaa3..6226569 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfilers.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfilers.java
index fa19473..d8f9ba3 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfilers.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/OperatorProfilers.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/Profiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/Profiler.java
index 0bf679b..b6e3852 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/Profiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/Profiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import de.hpi.isg.profiledb.instrumentation.StopWatch;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SinkProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SinkProfiler.java
index 2a35eb0..f162974 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SinkProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SinkProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SourceProfiler.java
index bb12492..45681b6 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/SourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/UnaryOperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/UnaryOperatorProfiler.java
index c240fad..09ccb8e 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/UnaryOperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/java/UnaryOperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.java;
 
 import org.apache.commons.lang3.Validate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicEstimationContext.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicEstimationContext.java
index f3db79a..5de2354 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicEstimationContext.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicEstimationContext.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadEstimator.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadEstimator.java
index 5710c6b..5f77fd0 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadEstimator.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.optimizer.cardinality.CardinalityEstimate;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimator.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimator.java
index fb86264..c45a75e 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimator.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimators.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimators.java
index 85283d8..c4eee1c 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimators.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/DynamicLoadProfileEstimators.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.json.JSONObject;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizer.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizer.java
index 4449d27..33149fd 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizer.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizer.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import gnu.trove.map.TObjectIntMap;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizerApp.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizerApp.java
index db736ef..3e3b2a5 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizerApp.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/GeneticOptimizerApp.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Individual.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Individual.java
index 887de48..4cf8160 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Individual.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Individual.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/LogEvaluator.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/LogEvaluator.java
index bd45680..7fa63c6 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/LogEvaluator.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/LogEvaluator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/OptimizationSpace.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/OptimizationSpace.java
index acae286..23d6ae4 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/OptimizationSpace.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/OptimizationSpace.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import org.apache.wayang.core.optimizer.costs.LoadProfileEstimator;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Variable.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Variable.java
index 5ea8901..d8a2add 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Variable.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/Variable.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log;
 
 import java.util.Random;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Battle.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Battle.java
index 7f651e5..175077f 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Battle.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Battle.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log.sampling;
 
 /**
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/ReservoirSampler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/ReservoirSampler.java
index 27de494..55a75e8 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/ReservoirSampler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/ReservoirSampler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log.sampling;
 
 import java.util.ArrayList;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Sampler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Sampler.java
index 177ed61..0fecc1b 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Sampler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/Sampler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log.sampling;
 
 import java.util.Collection;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/TournamentSampler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/TournamentSampler.java
index 366ef08..35edebb 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/TournamentSampler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/log/sampling/TournamentSampler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.log.sampling;
 
 import java.util.ArrayList;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/BinaryOperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/BinaryOperatorProfiler.java
index 2e3d12c..e63a177 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/BinaryOperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/BinaryOperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/Main.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/Main.java
index f0cf39d..c4412ca 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/Main.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/Main.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import de.hpi.isg.profiledb.instrumentation.StopWatch;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/OperatorProfilers.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/OperatorProfilers.java
index 242daeb..384c3a8 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/OperatorProfilers.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/OperatorProfilers.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SinkProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SinkProfiler.java
index 794c14e..351ce6b 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SinkProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SinkProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkCollectionSourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkCollectionSourceProfiler.java
index e0a38ec..22368ff 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkCollectionSourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkCollectionSourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkOperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkOperatorProfiler.java
index 1cb6303..e67f9c0 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkOperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkOperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkSourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkSourceProfiler.java
index 23c0214..7f35839 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkSourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkSourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkTextFileSourceProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkTextFileSourceProfiler.java
index 94fe48b..408c931 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkTextFileSourceProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkTextFileSourceProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkUnaryOperatorProfiler.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkUnaryOperatorProfiler.java
index 79a6bd9..f59a357 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkUnaryOperatorProfiler.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/spark/SparkUnaryOperatorProfiler.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.spark;
 
 import org.apache.spark.api.java.JavaRDD;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/ProfilingUtils.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/ProfilingUtils.java
index f460ded..d122f1d 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/ProfilingUtils.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/ProfilingUtils.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.util;
 
 import org.apache.wayang.core.api.Job;
diff --git a/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/RrdAccessor.java b/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/RrdAccessor.java
index 4f23a04..93a064e 100644
--- a/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/RrdAccessor.java
+++ b/wayang-profiler/src/main/java/org/apache/wayang/profiler/util/RrdAccessor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.profiler.util;
 
 import org.rrd4j.ConsolFun;


[incubator-wayang] 08/16: Add header licence to files in wayang-giraph

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 5022a4220f4f95deef58b11117dd2bb4093a4aea
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:19:30 2021 -0300

    Add header licence to files in wayang-giraph
---
 wayang-platforms/wayang-giraph/pom.xml                 | 11 +++++++++++
 .../wayang/giraph/Algorithm/PageRankAlgorithm.java     | 18 ++++++++++++++++++
 .../wayang/giraph/Algorithm/PageRankParameters.java    | 18 ++++++++++++++++++
 .../src/main/java/org/apache/wayang/giraph/Giraph.java | 18 ++++++++++++++++++
 .../wayang/giraph/channels/ChannelConversions.java     | 18 ++++++++++++++++++
 .../apache/wayang/giraph/execution/GiraphExecutor.java | 18 ++++++++++++++++++
 .../org/apache/wayang/giraph/mappings/Mappings.java    | 18 ++++++++++++++++++
 .../apache/wayang/giraph/mappings/PageRankMapping.java | 18 ++++++++++++++++++
 .../giraph/operators/GiraphExecutionOperator.java      | 18 ++++++++++++++++++
 .../giraph/operators/GiraphPageRankOperator.java       | 18 ++++++++++++++++++
 .../apache/wayang/giraph/platform/GiraphPlatform.java  | 18 ++++++++++++++++++
 .../org/apache/wayang/giraph/plugin/GiraphPlugin.java  | 18 ++++++++++++++++++
 .../giraph/operators/GiraphPagaRankOperatorTest.java   | 18 ++++++++++++++++++
 13 files changed, 227 insertions(+)

diff --git a/wayang-platforms/wayang-giraph/pom.xml b/wayang-platforms/wayang-giraph/pom.xml
index ad50de9..8489595 100644
--- a/wayang-platforms/wayang-giraph/pom.xml
+++ b/wayang-platforms/wayang-giraph/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankAlgorithm.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankAlgorithm.java
index d09e0c7..1bf2ad1 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankAlgorithm.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankAlgorithm.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.Algorithm;
 
 import com.google.common.collect.Lists;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankParameters.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankParameters.java
index dde3b9b..20f7761 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankParameters.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Algorithm/PageRankParameters.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.Algorithm;
 
 import org.apache.wayang.core.api.exception.WayangException;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Giraph.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Giraph.java
index dab60e9..9bb9d2f 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Giraph.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/Giraph.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph;
 
 import org.apache.wayang.giraph.platform.GiraphPlatform;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/channels/ChannelConversions.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/channels/ChannelConversions.java
index d31f005..cd1eb61 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.channels;
 
 import org.apache.wayang.core.optimizer.channels.ChannelConversion;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/execution/GiraphExecutor.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/execution/GiraphExecutor.java
index 1d9a8f6..86e7aa1 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/execution/GiraphExecutor.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/execution/GiraphExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.execution;
 
 import org.apache.giraph.conf.GiraphConfiguration;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/Mappings.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/Mappings.java
index bceb89f..7f98c14 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/Mappings.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.mappings;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/PageRankMapping.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/PageRankMapping.java
index fe3a92b..cc21b99 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/PageRankMapping.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/mappings/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.mappings;
 
 import org.apache.wayang.basic.operators.PageRankOperator;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphExecutionOperator.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphExecutionOperator.java
index e19dd5c..21f9b86 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphExecutionOperator.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.operators;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphPageRankOperator.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphPageRankOperator.java
index c6085cf..c1fc5ed 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphPageRankOperator.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/operators/GiraphPageRankOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.operators;
 
 import org.apache.giraph.conf.GiraphConfiguration;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/platform/GiraphPlatform.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/platform/GiraphPlatform.java
index 9b27814..d267e25 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/platform/GiraphPlatform.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/platform/GiraphPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.platform;
 
 import org.apache.giraph.conf.GiraphConfiguration;
diff --git a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/plugin/GiraphPlugin.java b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/plugin/GiraphPlugin.java
index 84d4cca..a1a075d 100644
--- a/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/plugin/GiraphPlugin.java
+++ b/wayang-platforms/wayang-giraph/src/main/java/org/apache/wayang/giraph/plugin/GiraphPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-giraph/src/test/java/org/apache/wayang/giraph/operators/GiraphPagaRankOperatorTest.java b/wayang-platforms/wayang-giraph/src/test/java/org/apache/wayang/giraph/operators/GiraphPagaRankOperatorTest.java
index cc65dbd..cfe177e 100644
--- a/wayang-platforms/wayang-giraph/src/test/java/org/apache/wayang/giraph/operators/GiraphPagaRankOperatorTest.java
+++ b/wayang-platforms/wayang-giraph/src/test/java/org/apache/wayang/giraph/operators/GiraphPagaRankOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.giraph.operators;
 
 import org.junit.Before;


[incubator-wayang] 09/16: Add header licence to files in wayang-graphchi

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

bertty pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/incubator-wayang.git

commit 41651f3182f8407087be64bc823cf74508adfb2e
Author: Bertty Contreras-Rojas <be...@scalytics.io>
AuthorDate: Sat Feb 6 14:20:28 2021 -0300

    Add header licence to files in wayang-graphchi
---
 wayang-platforms/wayang-graphchi/pom.xml               | 11 +++++++++++
 .../main/java/org/apache/wayang/graphchi/GraphChi.java | 18 ++++++++++++++++++
 .../wayang/graphchi/channels/ChannelConversions.java   | 18 ++++++++++++++++++
 .../wayang/graphchi/execution/GraphChiExecutor.java    | 18 ++++++++++++++++++
 .../org/apache/wayang/graphchi/mappings/Mappings.java  | 18 ++++++++++++++++++
 .../wayang/graphchi/mappings/PageRankMapping.java      | 18 ++++++++++++++++++
 .../graphchi/operators/GraphChiExecutionOperator.java  | 18 ++++++++++++++++++
 .../graphchi/operators/GraphChiPageRankOperator.java   | 18 ++++++++++++++++++
 .../wayang/graphchi/platform/GraphChiPlatform.java     | 18 ++++++++++++++++++
 .../apache/wayang/graphchi/plugin/GraphChiPlugin.java  | 18 ++++++++++++++++++
 .../operators/GraphChiPageRankOperatorTest.java        | 18 ++++++++++++++++++
 11 files changed, 191 insertions(+)

diff --git a/wayang-platforms/wayang-graphchi/pom.xml b/wayang-platforms/wayang-graphchi/pom.xml
index 81dddf6..93c519d 100644
--- a/wayang-platforms/wayang-graphchi/pom.xml
+++ b/wayang-platforms/wayang-graphchi/pom.xml
@@ -1,4 +1,15 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  Licensed 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. See accompanying LICENSE file.
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
     <parent>
         <artifactId>wayang-platforms</artifactId>
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/GraphChi.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/GraphChi.java
index 965555a..e20f988 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/GraphChi.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/GraphChi.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi;
 
 import org.apache.wayang.graphchi.platform.GraphChiPlatform;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/channels/ChannelConversions.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/channels/ChannelConversions.java
index 3068050..326ccae 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/channels/ChannelConversions.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/channels/ChannelConversions.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.channels;
 
 import org.apache.wayang.core.optimizer.channels.ChannelConversion;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/execution/GraphChiExecutor.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/execution/GraphChiExecutor.java
index feaac70..1d6120d 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/execution/GraphChiExecutor.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/execution/GraphChiExecutor.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.execution;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/Mappings.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/Mappings.java
index 18322c0..88e9f5f 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/Mappings.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/Mappings.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.mappings;
 
 import org.apache.wayang.core.mapping.Mapping;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/PageRankMapping.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/PageRankMapping.java
index d53e610..cd83b07 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/PageRankMapping.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/mappings/PageRankMapping.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.mappings;
 
 import org.apache.wayang.basic.operators.PageRankOperator;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiExecutionOperator.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiExecutionOperator.java
index 0af579b..a7f5218 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiExecutionOperator.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiExecutionOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.operators;
 
 import org.apache.wayang.core.optimizer.OptimizationContext;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperator.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperator.java
index 46817ad..68148bb 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperator.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperator.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.operators;
 
 import edu.cmu.graphchi.ChiFilenames;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/platform/GraphChiPlatform.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/platform/GraphChiPlatform.java
index 84a7af2..1d937ff 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/platform/GraphChiPlatform.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/platform/GraphChiPlatform.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.platform;
 
 import edu.cmu.graphchi.io.CompressedIO;
diff --git a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/plugin/GraphChiPlugin.java b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/plugin/GraphChiPlugin.java
index cc94397..50d52b1 100644
--- a/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/plugin/GraphChiPlugin.java
+++ b/wayang-platforms/wayang-graphchi/src/main/java/org/apache/wayang/graphchi/plugin/GraphChiPlugin.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.plugin;
 
 import org.apache.wayang.core.api.Configuration;
diff --git a/wayang-platforms/wayang-graphchi/src/test/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperatorTest.java b/wayang-platforms/wayang-graphchi/src/test/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperatorTest.java
index 339e537..2cf9f3a 100644
--- a/wayang-platforms/wayang-graphchi/src/test/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperatorTest.java
+++ b/wayang-platforms/wayang-graphchi/src/test/java/org/apache/wayang/graphchi/operators/GraphChiPageRankOperatorTest.java
@@ -1,3 +1,21 @@
+/*
+ * 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 org.apache.wayang.graphchi.operators;
 
 import org.junit.Before;